| Modifier and Type | Class and Description | 
|---|---|
(package private) static class  | 
FanOutOneBlockAsyncDFSOutputHelper.CancelOnClose  | 
| Modifier and Type | Method and Description | 
|---|---|
void | 
FanOutOneBlockAsyncDFSOutput.recoverAndClose(CancelableProgressable reporter)
The close method when error occurred. 
 | 
void | 
AsyncFSOutput.recoverAndClose(CancelableProgressable reporter)
The close method when error occurred. 
 | 
void | 
WrapperAsyncFSOutput.recoverAndClose(CancelableProgressable reporter)  | 
| Modifier and Type | Method and Description | 
|---|---|
SplitLogWorker.TaskExecutor.Status | 
SplitLogWorker.TaskExecutor.exec(String name,
    CancelableProgressable p)  | 
(package private) long | 
HRegion.initialize(CancelableProgressable reporter)
Initialize this region. 
 | 
private long | 
HRegion.initializeRegionInternals(CancelableProgressable reporter,
                         MonitoredTask status)  | 
private long | 
HRegion.initializeStores(CancelableProgressable reporter,
                MonitoredTask status)
Open all Stores. 
 | 
private void | 
HRegion.initializeWarmup(CancelableProgressable reporter)  | 
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,
           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,
           RegionServerServices rsServices,
           CancelableProgressable reporter)
Open a Region. 
 | 
static Region | 
HRegion.openHRegion(Region other,
           CancelableProgressable reporter)  | 
static HRegion | 
HRegion.openHRegion(RegionInfo info,
           TableDescriptor htd,
           WAL wal,
           org.apache.hadoop.conf.Configuration conf,
           RegionServerServices rsServices,
           CancelableProgressable reporter)
Open a Region. 
 | 
private long | 
HRegion.replayRecoveredEdits(org.apache.hadoop.fs.Path edits,
                    Map<byte[],Long> maxSeqIdInStores,
                    CancelableProgressable reporter,
                    org.apache.hadoop.fs.FileSystem fs)  | 
private long | 
HRegion.replayRecoveredEditsForPaths(long minSeqIdForTheRegion,
                            org.apache.hadoop.fs.FileSystem fs,
                            NavigableSet<org.apache.hadoop.fs.Path> files,
                            CancelableProgressable reporter,
                            org.apache.hadoop.fs.Path regionDir)  | 
protected long | 
HRegion.replayRecoveredEditsIfAny(Map<byte[],Long> maxSeqIdInStores,
                         CancelableProgressable reporter,
                         MonitoredTask status)
Read the edits put under this region by wal splitting process. 
 | 
static void | 
HRegion.warmupHRegion(RegionInfo info,
             TableDescriptor htd,
             WAL wal,
             org.apache.hadoop.conf.Configuration conf,
             RegionServerServices rsServices,
             CancelableProgressable reporter)  | 
| Modifier and Type | Field and Description | 
|---|---|
private CancelableProgressable | 
WALSplitterHandler.reporter  | 
| Constructor and Description | 
|---|
WALSplitterHandler(Server server,
                  SplitLogWorkerCoordination coordination,
                  SplitLogWorkerCoordination.SplitTaskDetails splitDetails,
                  CancelableProgressable reporter,
                  AtomicInteger inProgressTasks,
                  SplitLogWorker.TaskExecutor splitTaskExecutor)  | 
| Modifier and Type | Method and Description | 
|---|---|
(package private) void | 
FSHDFSUtils.checkIfCancelled(CancelableProgressable reporter)  | 
(package private) boolean | 
FSHDFSUtils.recoverDFSFileLease(org.apache.hadoop.hdfs.DistributedFileSystem dfs,
                   org.apache.hadoop.fs.Path p,
                   org.apache.hadoop.conf.Configuration conf,
                   CancelableProgressable reporter)  | 
void | 
FSMapRUtils.recoverFileLease(org.apache.hadoop.fs.FileSystem fs,
                org.apache.hadoop.fs.Path p,
                org.apache.hadoop.conf.Configuration conf,
                CancelableProgressable reporter)  | 
void | 
FSHDFSUtils.recoverFileLease(org.apache.hadoop.fs.FileSystem fs,
                org.apache.hadoop.fs.Path p,
                org.apache.hadoop.conf.Configuration conf,
                CancelableProgressable reporter)
Recover the lease from HDFS, retrying multiple times. 
 | 
abstract void | 
FSUtils.recoverFileLease(org.apache.hadoop.fs.FileSystem fs,
                org.apache.hadoop.fs.Path p,
                org.apache.hadoop.conf.Configuration conf,
                CancelableProgressable reporter)
Recover file lease. 
 | 
| Modifier and Type | Field and Description | 
|---|---|
protected CancelableProgressable | 
WALSplitter.OutputSink.reporter  | 
| Modifier and Type | Method and Description | 
|---|---|
WAL.Reader | 
WALFactory.createReader(org.apache.hadoop.fs.FileSystem fs,
            org.apache.hadoop.fs.Path path,
            CancelableProgressable reporter)
Create a reader for the WAL. 
 | 
WAL.Reader | 
WALFactory.createReader(org.apache.hadoop.fs.FileSystem fs,
            org.apache.hadoop.fs.Path path,
            CancelableProgressable reporter,
            boolean allowCustom)  | 
(package private) static WAL.Reader | 
WALFactory.createReader(org.apache.hadoop.fs.FileSystem fs,
            org.apache.hadoop.fs.Path path,
            org.apache.hadoop.conf.Configuration configuration,
            CancelableProgressable reporter)
Create a reader for the given path, accept custom reader classes from conf. 
 | 
protected WAL.Reader | 
WALSplitter.getReader(org.apache.hadoop.fs.FileStatus file,
         boolean skipErrors,
         CancelableProgressable reporter)
Create a new  
WAL.Reader for reading logs to split. | 
protected WAL.Reader | 
WALSplitter.getReader(org.apache.hadoop.fs.Path curLogFile,
         CancelableProgressable reporter)
Create a new  
WAL.Reader for reading logs to split. | 
(package private) void | 
WALSplitter.OutputSink.setReporter(CancelableProgressable reporter)  | 
(package private) boolean | 
WALSplitter.splitLogFile(org.apache.hadoop.fs.FileStatus logfile,
            CancelableProgressable reporter)
log splitting implementation, splits one log file. 
 | 
static boolean | 
WALSplitter.splitLogFile(org.apache.hadoop.fs.Path walDir,
            org.apache.hadoop.fs.FileStatus logfile,
            org.apache.hadoop.fs.FileSystem walFS,
            org.apache.hadoop.conf.Configuration conf,
            CancelableProgressable reporter,
            LastSequenceId idChecker,
            SplitLogWorkerCoordination splitLogWorkerCoordination,
            WALFactory factory)
Splits a WAL file into region's recovered-edits directory. 
 | 
Copyright © 2007–2019 The Apache Software Foundation. All rights reserved.