Uses of Interface
org.apache.hadoop.hbase.util.CancelableProgressable
Package
Description
-
Uses of CancelableProgressable in org.apache.hadoop.hbase.io.asyncfs
Modifier and TypeClassDescription(package private) static final class
Modifier and TypeMethodDescriptionvoid
AsyncFSOutput.recoverAndClose
(CancelableProgressable reporter) The close method when error occurred.void
FanOutOneBlockAsyncDFSOutput.recoverAndClose
(CancelableProgressable reporter) The close method when error occurred.void
WrapperAsyncFSOutput.recoverAndClose
(CancelableProgressable reporter) -
Uses of CancelableProgressable in org.apache.hadoop.hbase.regionserver
Modifier and TypeMethodDescriptionSplitLogWorker.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 void
HRegion.initializeRegionReplicationSink
(CancelableProgressable reporter, MonitoredTask status) private long
HRegion.initializeStores
(CancelableProgressable reporter, MonitoredTask status) Open all Stores.private long
HRegion.initializeStores
(CancelableProgressable reporter, MonitoredTask status, boolean warmup) private void
HRegion.initializeWarmup
(CancelableProgressable reporter) 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
(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, 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 Region
HRegion.openHRegion
(Region other, CancelableProgressable reporter) private HRegion
HRegion.openHRegion
(CancelableProgressable reporter) Open HRegion.static HRegion
HRegion.openHRegionFromTableDir
(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path tableDir, RegionInfo info, TableDescriptor htd, WAL wal, 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) (package private) long
HRegion.replayRecoveredEditsIfAny
(Map<byte[], Long> maxSeqIdInStores, CancelableProgressable reporter, MonitoredTask status) Read the edits put under this region by wal splitting process.(package private) static SplitLogWorker.TaskExecutor.Status
SplitLogWorker.splitLog
(String filename, CancelableProgressable p, org.apache.hadoop.conf.Configuration conf, RegionServerServices server, LastSequenceId sequenceIdChecker, WALFactory factory) Deprecated.Returns Result either DONE, RESIGNED, or ERR.static HRegion
HRegion.warmupHRegion
(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) -
Uses of CancelableProgressable in org.apache.hadoop.hbase.regionserver.handler
Modifier and TypeFieldDescriptionprivate final CancelableProgressable
WALSplitterHandler.reporter
Deprecated.ModifierConstructorDescriptionWALSplitterHandler
(Server server, SplitLogWorkerCoordination coordination, SplitLogWorkerCoordination.SplitTaskDetails splitDetails, CancelableProgressable reporter, AtomicInteger inProgressTasks, SplitLogWorker.TaskExecutor splitTaskExecutor) Deprecated. -
Uses of CancelableProgressable in org.apache.hadoop.hbase.util
Modifier and TypeMethodDescriptionprivate static void
RecoverLeaseFSUtils.checkIfCancelled
(CancelableProgressable reporter) private static boolean
RecoverLeaseFSUtils.recoverDFSFileLease
(org.apache.hadoop.fs.FileSystem dfs, org.apache.hadoop.fs.Path p, org.apache.hadoop.conf.Configuration conf, CancelableProgressable reporter) static void
RecoverLeaseFSUtils.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 Hadoop file system, retrying multiple times. -
Uses of CancelableProgressable in org.apache.hadoop.hbase.wal
Modifier and TypeMethodDescriptionWALFactory.createStreamReader
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path path, CancelableProgressable reporter) Create a one-way stream reader for the WAL.WALFactory.createStreamReader
(org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path path, CancelableProgressable reporter, long startPosition) Create a one-way stream reader for the WAL, and start reading from the givenstartPosition
.protected WALStreamReader
WALSplitter.getReader
(org.apache.hadoop.fs.FileStatus walStatus, boolean skipErrors, CancelableProgressable cancel) Create a newWALStreamReader
for reading logs to split.private WALStreamReader
WALSplitter.getReader
(org.apache.hadoop.fs.Path curLogFile, CancelableProgressable reporter) Create a newWALStreamReader
for reading logs to split.(package private) void
OutputSink.setReporter
(CancelableProgressable reporter) 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, RegionServerServices rsServices) Splits a WAL file.(package private) WALSplitter.SplitWALResult
WALSplitter.splitWAL
(org.apache.hadoop.fs.FileStatus walStatus, CancelableProgressable cancel) WAL splitting implementation, splits one WAL file.