Constructor and Description |
---|
FlushTableSubprocedure(ProcedureMember member,
ForeignExceptionDispatcher errorListener,
long wakeFrequency,
long timeout,
List<HRegion> regions,
String table,
org.apache.hadoop.hbase.procedure.flush.RegionServerFlushTableProcedureManager.FlushTableSubprocedurePool taskManager) |
Modifier and Type | Field and Description |
---|---|
protected HRegion |
FlushPolicy.region
The region configured for this flush policy.
|
protected HRegion |
RegionSplitPolicy.region
The region configured for this split policy.
|
protected HRegion |
HStore.region |
Modifier and Type | Field and Description |
---|---|
protected Map<String,HRegion> |
HRegionServer.onlineRegions
Map of regions currently being served by this region server.
|
Modifier and Type | Method and Description |
---|---|
static HRegion |
HRegion.createHRegion(RegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
TableDescriptor hTableDescriptor,
WAL wal) |
static HRegion |
HRegion.createHRegion(RegionInfo info,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.conf.Configuration conf,
TableDescriptor hTableDescriptor,
WAL wal,
boolean initialize)
Convenience method creating new HRegions.
|
HRegion |
HStore.getHRegion() |
HRegion |
HRegionServer.getOnlineRegion(byte[] regionName) |
HRegion |
RegionServerServices.PostOpenDeployContext.getRegion() |
protected HRegion |
HRegionServer.getRegion(byte[] regionName)
Protected Utility method for safely obtaining an HRegion handle.
|
HRegion |
RSRpcServices.getRegion(HBaseProtos.RegionSpecifier regionSpecifier)
Find the HRegion based on a region specifier
|
HRegion |
HRegionServer.getRegion(String encodedRegionName) |
protected HRegion |
HRegionServer.getRegionByEncodedName(byte[] regionName,
String encodedRegionName) |
HRegion |
HRegionServer.getRegionByEncodedName(String encodedRegionName) |
protected HRegion |
HRegion.openHRegion(CancelableProgressable reporter)
Open HRegion.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
org.apache.hadoop.fs.Path tableDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
RegionInfo info,
TableDescriptor htd,
WAL wal)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path rootDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(HRegion other,
CancelableProgressable reporter)
Useful when reopening a closed region (normally for unit tests)
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf)
Open a Region.
|
static HRegion |
HRegion.openHRegion(org.apache.hadoop.fs.Path rootDir,
RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openHRegion(RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf)
Open a Region.
|
static HRegion |
HRegion.openHRegion(RegionInfo info,
TableDescriptor htd,
WAL wal,
org.apache.hadoop.conf.Configuration conf,
RegionServerServices rsServices,
CancelableProgressable reporter)
Open a Region.
|
static HRegion |
HRegion.openReadOnlyFileSystemHRegion(org.apache.hadoop.conf.Configuration conf,
org.apache.hadoop.fs.FileSystem fs,
org.apache.hadoop.fs.Path tableDir,
RegionInfo info,
TableDescriptor htd)
Open a Region on a read-only file-system (like hdfs snapshots)
|
Modifier and Type | Method and Description |
---|---|
Collection<HRegion> |
HRegionServer.getOnlineRegionsLocalContext()
For tests, web ui and metrics.
|
List<HRegion> |
HRegionServer.getRegions() |
List<HRegion> |
HRegionServer.getRegions(TableName tableName)
Gets the online regions of the specified table.
|
Modifier and Type | Method and Description |
---|---|
void |
MutableOnlineRegions.addRegion(HRegion r)
Add to online regions.
|
void |
HRegionServer.addRegion(HRegion region) |
void |
SecureBulkLoadManager.cleanupBulkLoad(HRegion region,
ClientProtos.CleanupBulkLoadRequest request) |
protected void |
FlushAllLargeStoresPolicy.configureForRegion(HRegion region) |
protected void |
BusyRegionSplitPolicy.configureForRegion(HRegion region) |
protected void |
DelimitedKeyPrefixRegionSplitPolicy.configureForRegion(HRegion region) |
protected void |
FlushNonSloppyStoresFirstPolicy.configureForRegion(HRegion region) |
protected void |
ConstantSizeRegionSplitPolicy.configureForRegion(HRegion region) |
protected void |
IncreasingToUpperBoundRegionSplitPolicy.configureForRegion(HRegion region) |
protected void |
KeyPrefixRegionSplitPolicy.configureForRegion(HRegion region) |
protected void |
FlushPolicy.configureForRegion(HRegion region)
Upon construction, this method will be called with the region to be governed.
|
protected void |
RegionSplitPolicy.configureForRegion(HRegion region)
Upon construction, this method will be called with the region
to be governed.
|
static FlushPolicy |
FlushPolicyFactory.create(HRegion region,
org.apache.hadoop.conf.Configuration conf)
Create the FlushPolicy configured for the given table.
|
static RegionSplitPolicy |
RegionSplitPolicy.create(HRegion region,
org.apache.hadoop.conf.Configuration conf)
Create the RegionSplitPolicy configured for the given table.
|
static HRegion |
HRegion.openHRegion(HRegion other,
CancelableProgressable reporter)
Useful when reopening a closed region (normally for unit tests)
|
void |
BaseRowProcessor.postBatchMutate(HRegion region) |
void |
RowProcessor.postBatchMutate(HRegion region)
Deprecated.
The hook to be executed after the process() and applying the Mutations to region.
|
void |
BaseRowProcessor.postProcess(HRegion region,
WALEdit walEdit,
boolean success) |
void |
RowProcessor.postProcess(HRegion region,
WALEdit walEdit,
boolean success)
Deprecated.
The hook to be executed after process() and applying the Mutations to region.
|
void |
BaseRowProcessor.preBatchMutate(HRegion region,
WALEdit walEdit) |
void |
RowProcessor.preBatchMutate(HRegion region,
WALEdit walEdit)
Deprecated.
The hook to be executed after the process() but before applying the Mutations to region.
|
String |
SecureBulkLoadManager.prepareBulkLoad(HRegion region,
ClientProtos.PrepareBulkLoadRequest request) |
void |
BaseRowProcessor.preProcess(HRegion region,
WALEdit walEdit) |
void |
RowProcessor.preProcess(HRegion region,
WALEdit walEdit)
Deprecated.
The hook to be executed before process().
|
void |
RowProcessor.process(long now,
HRegion region,
List<Mutation> mutations,
WALEdit walEdit)
Deprecated.
HRegion handles the locks and MVCC and invokes this method properly.
|
boolean |
MutableOnlineRegions.removeRegion(HRegion r,
ServerName destination)
Removes the given Region from the list of onlineRegions.
|
boolean |
HRegionServer.removeRegion(HRegion r,
ServerName destination) |
void |
CompactSplit.requestCompaction(HRegion region,
HStore store,
String why,
int priority,
CompactionLifeCycleTracker tracker,
User user) |
void |
CompactSplit.requestCompaction(HRegion region,
String why,
int priority,
CompactionLifeCycleTracker tracker,
User user) |
boolean |
FlushRequester.requestDelayedFlush(HRegion region,
long delay,
boolean forceFlushAllStores)
Tell the listener the cache needs to be flushed after a delay
|
boolean |
FlushRequester.requestFlush(HRegion region,
boolean forceFlushAllStores,
FlushLifeCycleTracker tracker)
Tell the listener the cache needs to be flushed.
|
void |
CompactSplit.requestSystemCompaction(HRegion region,
HStore store,
String why) |
void |
CompactSplit.requestSystemCompaction(HRegion region,
String why) |
Map<byte[],List<org.apache.hadoop.fs.Path>> |
SecureBulkLoadManager.secureBulkLoadHFiles(HRegion region,
ClientProtos.BulkLoadHFileRequest request) |
protected void |
FlushLargeStoresPolicy.setFlushSizeLowerBounds(HRegion region) |
Constructor and Description |
---|
HMobStore(HRegion region,
ColumnFamilyDescriptor family,
org.apache.hadoop.conf.Configuration confParam) |
HStore(HRegion region,
ColumnFamilyDescriptor family,
org.apache.hadoop.conf.Configuration confParam)
Constructor
|
MetricsRegionWrapperImpl(HRegion region) |
PostOpenDeployContext(HRegion region,
long masterSystemTime) |
RegionCoprocessorHost(HRegion region,
RegionServerServices rsServices,
org.apache.hadoop.conf.Configuration conf)
Constructor
|
RegionServicesForStores(HRegion region,
RegionServerServices rsServices) |
Modifier and Type | Method and Description |
---|---|
void |
CompactionRequester.requestCompaction(HRegion region,
HStore store,
String why,
int priority,
CompactionLifeCycleTracker tracker,
User user)
Request compaction on the given store.
|
void |
CompactionRequester.requestCompaction(HRegion region,
String why,
int priority,
CompactionLifeCycleTracker tracker,
User user)
Request compaction on all the stores of the given region.
|
Constructor and Description |
---|
RegionReplicaFlushHandler(Server server,
ClusterConnection connection,
RpcRetryingCallerFactory rpcRetryingCallerFactory,
RpcControllerFactory rpcControllerFactory,
int operationTimeout,
HRegion region) |
Constructor and Description |
---|
RegionSnapshotTask(HRegion region,
SnapshotProtos.SnapshotDescription snapshotDesc,
boolean skipFlush,
ForeignExceptionDispatcher monitor) |
Constructor and Description |
---|
FlushSnapshotSubprocedure(ProcedureMember member,
ForeignExceptionDispatcher errorListener,
long wakeFrequency,
long timeout,
List<HRegion> regions,
SnapshotProtos.SnapshotDescription snapshot,
org.apache.hadoop.hbase.regionserver.snapshot.RegionServerSnapshotManager.SnapshotSubprocedurePool taskManager) |
Modifier and Type | Method and Description |
---|---|
void |
SnapshotManifest.addRegion(HRegion region)
Creates a 'manifest' for the specified region, by reading directly from the HRegion object.
|
protected void |
SnapshotManifest.addRegion(HRegion region,
org.apache.hadoop.hbase.snapshot.SnapshotManifest.RegionVisitor visitor) |
Modifier and Type | Method and Description |
---|---|
static HRegion |
HBaseFsckRepair.createHDFSRegionDir(org.apache.hadoop.conf.Configuration conf,
RegionInfo hri,
TableDescriptor htd)
Creates, flushes, and closes a new region.
|
Modifier and Type | Method and Description |
---|---|
void |
ModifyRegionUtils.RegionFillTask.fillRegion(HRegion region) |
static boolean |
ServerRegionReplicaUtil.isReadOnly(HRegion region)
Returns whether this region replica can accept writes.
|
static boolean |
ServerRegionReplicaUtil.shouldReplayRecoveredEdits(HRegion region)
Returns whether to replay the recovered edits to flush the results.
|
Copyright © 2007–2019 Cloudera. All rights reserved.