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