Uses of Interface
org.apache.hadoop.hbase.util.CancelableProgressable
Packages that use CancelableProgressable
Package
Description
-
Uses of CancelableProgressable in org.apache.hadoop.hbase.io.asyncfs
Classes in org.apache.hadoop.hbase.io.asyncfs that implement CancelableProgressableModifier and TypeClassDescription(package private) static final classMethods in org.apache.hadoop.hbase.io.asyncfs with parameters of type CancelableProgressableModifier and TypeMethodDescriptionvoidAsyncFSOutput.recoverAndClose(CancelableProgressable reporter) The close method when error occurred.voidFanOutOneBlockAsyncDFSOutput.recoverAndClose(CancelableProgressable reporter) The close method when error occurred.voidWrapperAsyncFSOutput.recoverAndClose(CancelableProgressable reporter) -
Uses of CancelableProgressable in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver with parameters of type CancelableProgressableModifier and TypeMethodDescriptionSplitLogWorker.TaskExecutor.exec(String name, CancelableProgressable p) (package private) longHRegion.initialize(CancelableProgressable reporter) Initialize this region.private longHRegion.initializeRegionInternals(CancelableProgressable reporter, MonitoredTask status) private longHRegion.initializeStores(CancelableProgressable reporter, MonitoredTask status) Open all Stores.private longHRegion.initializeStores(CancelableProgressable reporter, MonitoredTask status, boolean warmup) private voidHRegion.initializeWarmup(CancelableProgressable reporter) static HRegionHRegion.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 HRegionHRegion.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 HRegionHRegion.openHRegion(RegionInfo info, TableDescriptor htd, WAL wal, org.apache.hadoop.conf.Configuration conf, RegionServerServices rsServices, CancelableProgressable reporter) Open a Region.static HRegionHRegion.openHRegion(HRegion other, CancelableProgressable reporter) Useful when reopening a closed region (normally for unit tests)static RegionHRegion.openHRegion(Region other, CancelableProgressable reporter) private HRegionHRegion.openHRegion(CancelableProgressable reporter) Open HRegion.static HRegionHRegion.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 longHRegion.replayRecoveredEdits(org.apache.hadoop.fs.Path edits, Map<byte[], Long> maxSeqIdInStores, CancelableProgressable reporter, org.apache.hadoop.fs.FileSystem fs) private longHRegion.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) longHRegion.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.StatusSplitLogWorker.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 HRegionHRegion.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
Fields in org.apache.hadoop.hbase.regionserver.handler declared as CancelableProgressableModifier and TypeFieldDescriptionprivate final CancelableProgressableWALSplitterHandler.reporterDeprecated.Constructors in org.apache.hadoop.hbase.regionserver.handler with parameters of type CancelableProgressableModifierConstructorDescriptionWALSplitterHandler(Server server, SplitLogWorkerCoordination coordination, SplitLogWorkerCoordination.SplitTaskDetails splitDetails, CancelableProgressable reporter, AtomicInteger inProgressTasks, SplitLogWorker.TaskExecutor splitTaskExecutor) Deprecated. -
Uses of CancelableProgressable in org.apache.hadoop.hbase.util
Methods in org.apache.hadoop.hbase.util with parameters of type CancelableProgressableModifier and TypeMethodDescriptionprivate static voidRecoverLeaseFSUtils.checkIfCancelled(CancelableProgressable reporter) private static booleanRecoverLeaseFSUtils.recoverDFSFileLease(org.apache.hadoop.hdfs.DistributedFileSystem dfs, org.apache.hadoop.fs.Path p, org.apache.hadoop.conf.Configuration conf, CancelableProgressable reporter) static voidRecoverLeaseFSUtils.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. -
Uses of CancelableProgressable in org.apache.hadoop.hbase.wal
Fields in org.apache.hadoop.hbase.wal declared as CancelableProgressableMethods in org.apache.hadoop.hbase.wal with parameters of type CancelableProgressableModifier 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 WALStreamReaderWALSplitter.getReader(org.apache.hadoop.fs.FileStatus walStatus, boolean skipErrors, CancelableProgressable cancel) Create a newWALStreamReaderfor reading logs to split.private WALStreamReaderWALSplitter.getReader(org.apache.hadoop.fs.Path curLogFile, CancelableProgressable reporter) Create a newWALStreamReaderfor reading logs to split.(package private) voidOutputSink.setReporter(CancelableProgressable reporter) static booleanWALSplitter.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.SplitWALResultWALSplitter.splitWAL(org.apache.hadoop.fs.FileStatus walStatus, CancelableProgressable cancel) WAL splitting implementation, splits one WAL file.