| Package | Description | 
|---|---|
| org.apache.hadoop.hbase.regionserver | |
| org.apache.hadoop.hbase.regionserver.handler | |
| org.apache.hadoop.hbase.util | |
| org.apache.hadoop.hbase.wal | 
| Modifier and Type | Method and Description | 
|---|---|
| SplitLogWorker.TaskExecutor.Status | SplitLogWorker.TaskExecutor. exec(String name,
    ZooKeeperProtos.SplitLogTask.RecoveryMode mode,
    CancelableProgressable p) | 
| 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,
           HRegionInfo info,
           HTableDescriptor 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,
           org.apache.hadoop.fs.Path tableDir,
           HRegionInfo info,
           HTableDescriptor 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(HRegionInfo info,
           HTableDescriptor htd,
           WAL wal,
           org.apache.hadoop.conf.Configuration conf,
           RegionServerServices rsServices,
           CancelableProgressable reporter)Open a Region. | 
| static HRegion | HRegion. openHRegion(org.apache.hadoop.fs.Path rootDir,
           HRegionInfo info,
           HTableDescriptor htd,
           WAL wal,
           org.apache.hadoop.conf.Configuration conf,
           RegionServerServices rsServices,
           CancelableProgressable reporter)Open a Region. | 
| static Region | HRegion. openHRegion(Region other,
           CancelableProgressable reporter) | 
| protected long | HRegion. replayRecoveredEditsIfAny(org.apache.hadoop.fs.Path regiondir,
                         Map<byte[],Long> maxSeqIdInStores,
                         CancelableProgressable reporter,
                         MonitoredTask status)Read the edits put under this region by wal splitting process. | 
| static void | HRegion. warmupHRegion(HRegionInfo info,
             HTableDescriptor htd,
             WAL wal,
             org.apache.hadoop.conf.Configuration conf,
             RegionServerServices rsServices,
             CancelableProgressable reporter) | 
| Constructor and Description | 
|---|
| WALSplitterHandler(Server server,
                  SplitLogWorkerCoordination coordination,
                  SplitLogWorkerCoordination.SplitTaskDetails splitDetails,
                  CancelableProgressable reporter,
                  AtomicInteger inProgressTasks,
                  SplitLogWorker.TaskExecutor splitTaskExecutor,
                  ZooKeeperProtos.SplitLogTask.RecoveryMode mode) | 
| Modifier and Type | Method and Description | 
|---|---|
| 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. | 
| 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. | 
| 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) | 
| protected WAL.Reader | WALSplitter. getReader(org.apache.hadoop.fs.FileStatus file,
         boolean skipErrors,
         CancelableProgressable reporter)Create a new  WAL.Readerfor reading logs to split. | 
| protected WAL.Reader | WALSplitter. getReader(org.apache.hadoop.fs.Path curLogFile,
         CancelableProgressable reporter)Create a new  WAL.Readerfor reading logs to split. | 
| static boolean | WALSplitter. splitLogFile(org.apache.hadoop.fs.Path rootDir,
            org.apache.hadoop.fs.FileStatus logfile,
            org.apache.hadoop.fs.FileSystem fs,
            org.apache.hadoop.conf.Configuration conf,
            CancelableProgressable reporter,
            LastSequenceId idChecker,
            CoordinatedStateManager cp,
            ZooKeeperProtos.SplitLogTask.RecoveryMode mode,
            WALFactory factory)Splits a WAL file into region's recovered-edits directory. | 
Copyright © 2007-2016 The Apache Software Foundation. All Rights Reserved.