Package | Description |
---|---|
org.apache.hadoop.hbase.util | |
org.apache.hadoop.hbase.util.hbck |
Modifier and Type | Field and Description |
---|---|
private HBaseFsck.HbckInfo |
HBaseFsck.CheckRegionConsistencyWorkItem.hbi |
private HBaseFsck.HbckInfo |
HBaseFsck.WorkItemHdfsRegionInfo.hbi |
Modifier and Type | Field and Description |
---|---|
(package private) List<HBaseFsck.HbckInfo> |
HBaseFsck.TableInfo.backwards |
(package private) static Comparator<HBaseFsck.HbckInfo> |
HBaseFsck.cmp |
private List<HBaseFsck.HbckInfo> |
HBaseFsck.orphanHdfsDirs
When initially looking at HDFS, we attempt to find any orphaned data.
|
(package private) Collection<HBaseFsck.HbckInfo> |
HBaseFsck.WorkItemOverlapMerge.overlapgroup |
(package private) com.google.common.collect.Multimap<byte[],HBaseFsck.HbckInfo> |
HBaseFsck.TableInfo.overlapGroups |
private TreeMap<String,HBaseFsck.HbckInfo> |
HBaseFsck.regionInfoMap
This map contains the state of all hbck items.
|
(package private) RegionSplitCalculator<HBaseFsck.HbckInfo> |
HBaseFsck.TableInfo.sc |
(package private) Map<org.apache.hadoop.fs.Path,HBaseFsck.HbckInfo> |
HBaseFsck.TableInfo.sidelinedRegions |
Modifier and Type | Method and Description |
---|---|
private HBaseFsck.HbckInfo |
HBaseFsck.getOrCreateInfo(String name)
Gets the entry in regionInfo corresponding to the the given encoded
region name.
|
Modifier and Type | Method and Description |
---|---|
com.google.common.collect.Multimap<byte[],HBaseFsck.HbckInfo> |
HBaseFsck.getOverlapGroups(TableName table) |
Modifier and Type | Method and Description |
---|---|
void |
HBaseFsck.TableInfo.addRegionInfo(HBaseFsck.HbckInfo hir) |
private void |
HBaseFsck.addSkippedRegion(HBaseFsck.HbckInfo hbi) |
private void |
HBaseFsck.adoptHdfsOrphan(HBaseFsck.HbckInfo hi)
Orphaned regions are regions without a .regioninfo file in them.
|
private void |
HBaseFsck.checkRegionConsistency(String key,
HBaseFsck.HbckInfo hbi)
Check a single region for consistency and correct deployment.
|
private void |
HBaseFsck.closeRegion(HBaseFsck.HbckInfo hi)
Attempts to undeploy a region from a region server based in information in
META.
|
private void |
HBaseFsck.deleteMetaRegion(HBaseFsck.HbckInfo hi)
Deletes region from meta table
|
private Set<String> |
HBaseFsck.getColumnFamilyList(Set<String> columns,
HBaseFsck.HbckInfo hbi)
To get the column family list according to the column family dirs
|
void |
HBaseFsck.TableInfo.IntegrityFixSuggester.handleDegenerateRegion(HBaseFsck.HbckInfo hi) |
void |
HBaseFsck.TableInfo.IntegrityFixSuggester.handleDuplicateStartKeys(HBaseFsck.HbckInfo r1,
HBaseFsck.HbckInfo r2) |
void |
HBaseFsck.TableInfo.IntegrityFixSuggester.handleOverlapInRegionChain(HBaseFsck.HbckInfo hi1,
HBaseFsck.HbckInfo hi2) |
void |
HBaseFsck.TableInfo.IntegrityFixSuggester.handleRegionStartKeyNotEmpty(HBaseFsck.HbckInfo hi) |
void |
HBaseFsck.TableInfo.HDFSIntegrityFixer.handleRegionStartKeyNotEmpty(HBaseFsck.HbckInfo next)
This is a special case hole -- when the first region of a table is
missing from META, HBase doesn't acknowledge the existance of the
table.
|
void |
HBaseFsck.TableInfo.IntegrityFixSuggester.handleSplit(HBaseFsck.HbckInfo r1,
HBaseFsck.HbckInfo r2) |
private void |
HBaseFsck.loadHdfsRegioninfo(HBaseFsck.HbckInfo hbi)
Read the .regioninfo file from the file system.
|
int |
HBaseFsck.mergeRegionDirs(org.apache.hadoop.fs.Path targetRegionDir,
HBaseFsck.HbckInfo contained)
Merge hdfs data by moving from contained HbckInfo into targetRegionDir.
|
void |
HBaseFsck.ErrorReporter.reportError(HBaseFsck.ErrorReporter.ERROR_CODE errorCode,
String message,
HBaseFsck.TableInfo table,
HBaseFsck.HbckInfo info) |
void |
HBaseFsck.PrintingErrorReporter.reportError(HBaseFsck.ErrorReporter.ERROR_CODE errorCode,
String message,
HBaseFsck.TableInfo table,
HBaseFsck.HbckInfo info) |
void |
HBaseFsck.ErrorReporter.reportError(HBaseFsck.ErrorReporter.ERROR_CODE errorCode,
String message,
HBaseFsck.TableInfo table,
HBaseFsck.HbckInfo info1,
HBaseFsck.HbckInfo info2) |
void |
HBaseFsck.PrintingErrorReporter.reportError(HBaseFsck.ErrorReporter.ERROR_CODE errorCode,
String message,
HBaseFsck.TableInfo table,
HBaseFsck.HbckInfo info1,
HBaseFsck.HbckInfo info2) |
private void |
HBaseFsck.resetSplitParent(HBaseFsck.HbckInfo hi)
Reset the split parent region info in meta table
|
(package private) org.apache.hadoop.fs.Path |
HBaseFsck.sidelineRegionDir(org.apache.hadoop.fs.FileSystem fs,
HBaseFsck.HbckInfo hi)
Sideline a region dir (instead of deleting it)
|
(package private) org.apache.hadoop.fs.Path |
HBaseFsck.sidelineRegionDir(org.apache.hadoop.fs.FileSystem fs,
String parentDir,
HBaseFsck.HbckInfo hi)
Sideline a region dir (instead of deleting it)
|
private void |
HBaseFsck.tryAssignmentRepair(HBaseFsck.HbckInfo hbi,
String msg) |
private void |
HBaseFsck.unassignMetaReplica(HBaseFsck.HbckInfo hi) |
private void |
HBaseFsck.undeployRegions(HBaseFsck.HbckInfo hi) |
private void |
HBaseFsck.undeployRegionsForHbi(HBaseFsck.HbckInfo hi) |
Modifier and Type | Method and Description |
---|---|
private void |
HBaseFsck.adoptHdfsOrphans(Collection<HBaseFsck.HbckInfo> orphanHdfsDirs)
Iterates through the list of all orphan/invalid regiondirs.
|
(package private) void |
HBaseFsck.TableInfo.dump(SortedSet<byte[]> splits,
com.google.common.collect.Multimap<byte[],HBaseFsck.HbckInfo> regions)
This dumps data in a visually reasonable way for visual debugging
|
void |
HBaseFsck.dumpOverlapProblems(com.google.common.collect.Multimap<byte[],HBaseFsck.HbckInfo> regions) |
void |
HBaseFsck.dumpSidelinedRegions(Map<org.apache.hadoop.fs.Path,HBaseFsck.HbckInfo> regions) |
void |
HBaseFsck.TableInfo.HDFSIntegrityFixer.handleOverlapGroup(Collection<HBaseFsck.HbckInfo> overlap)
This takes set of overlapping regions and merges them into a single
region.
|
(package private) void |
HBaseFsck.TableInfo.HDFSIntegrityFixer.mergeOverlaps(Collection<HBaseFsck.HbckInfo> overlap) |
(package private) void |
HBaseFsck.TableInfo.HDFSIntegrityFixer.removeParentsAndFixSplits(Collection<HBaseFsck.HbckInfo> overlap) |
(package private) void |
HBaseFsck.TableInfo.HDFSIntegrityFixer.sidelineBigOverlaps(Collection<HBaseFsck.HbckInfo> bigOverlap)
Sideline some regions in a big overlap group so that it
will have fewer regions, and it is easier to merge them later on.
|
Constructor and Description |
---|
HBaseFsck.CheckRegionConsistencyWorkItem(String key,
HBaseFsck.HbckInfo hbi) |
HBaseFsck.WorkItemHdfsRegionInfo(HBaseFsck.HbckInfo hbi,
HBaseFsck hbck,
HBaseFsck.ErrorReporter errors) |
Constructor and Description |
---|
HBaseFsck.WorkItemOverlapMerge(Collection<HBaseFsck.HbckInfo> overlapgroup,
TableIntegrityErrorHandler handler) |
Modifier and Type | Method and Description |
---|---|
void |
TableIntegrityErrorHandlerImpl.handleDegenerateRegion(HBaseFsck.HbckInfo hi)
Callback for handling a region that has the same start and end key.
|
void |
TableIntegrityErrorHandler.handleDegenerateRegion(HBaseFsck.HbckInfo hi)
Callback for handling a region that has the same start and end key.
|
void |
TableIntegrityErrorHandlerImpl.handleDuplicateStartKeys(HBaseFsck.HbckInfo hi1,
HBaseFsck.HbckInfo hi2)
Callback for handling two regions that have the same start key.
|
void |
TableIntegrityErrorHandler.handleDuplicateStartKeys(HBaseFsck.HbckInfo hi1,
HBaseFsck.HbckInfo hi2)
Callback for handling two regions that have the same start key.
|
void |
TableIntegrityErrorHandlerImpl.handleOverlapInRegionChain(HBaseFsck.HbckInfo hi1,
HBaseFsck.HbckInfo hi2)
Callback for handling two reigons that overlap in some arbitrary way.
|
void |
TableIntegrityErrorHandler.handleOverlapInRegionChain(HBaseFsck.HbckInfo hi1,
HBaseFsck.HbckInfo hi2)
Callback for handling two reigons that overlap in some arbitrary way.
|
void |
TableIntegrityErrorHandlerImpl.handleRegionStartKeyNotEmpty(HBaseFsck.HbckInfo hi)
Callback for handling case where a Table has a first region that does not
have an empty start key.
|
void |
TableIntegrityErrorHandler.handleRegionStartKeyNotEmpty(HBaseFsck.HbckInfo hi)
Callback for handling case where a Table has a first region that does not
have an empty start key.
|
void |
TableIntegrityErrorHandler.handleSplit(HBaseFsck.HbckInfo hi1,
HBaseFsck.HbckInfo hi2)
Callback for handling two regions that have the same regionID
a specific case of a split
|
Modifier and Type | Method and Description |
---|---|
void |
TableIntegrityErrorHandlerImpl.handleOverlapGroup(Collection<HBaseFsck.HbckInfo> overlap)
Callback for handling an group of regions that overlap.
|
void |
TableIntegrityErrorHandler.handleOverlapGroup(Collection<HBaseFsck.HbckInfo> overlap)
Callback for handling an group of regions that overlap.
|
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.