Uses of Interface
org.apache.hadoop.hbase.monitoring.MonitoredTask
Packages that use MonitoredTask
Package
Description
-
Uses of MonitoredTask in org.apache.hadoop.hbase.master
Methods in org.apache.hadoop.hbase.master with parameters of type MonitoredTaskModifier and TypeMethodDescriptionprivate voidHMaster.waitForRegionServers(MonitoredTask status) voidServerManager.waitForRegionServers(MonitoredTask status) Wait for the region servers to report in.private voidSplitLogManager.waitForSplittingCompletion(SplitLogManager.TaskBatch batch, MonitoredTask status) Deprecated. -
Uses of MonitoredTask in org.apache.hadoop.hbase.master.procedure
Fields in org.apache.hadoop.hbase.master.procedure declared as MonitoredTaskModifier and TypeFieldDescriptionprivate MonitoredTaskCloneSnapshotProcedure.monitorStatusprivate MonitoredTaskRestoreSnapshotProcedure.monitorStatusprivate MonitoredTaskServerCrashProcedure.statusprivate MonitoredTaskSnapshotProcedure.statusMethods in org.apache.hadoop.hbase.master.procedure that return MonitoredTaskModifier and TypeMethodDescriptionprivate MonitoredTaskCloneSnapshotProcedure.getMonitorStatus()Set up monitor status if it is not created.private MonitoredTaskRestoreSnapshotProcedure.getMonitorStatus()Set up monitor status if it is not created. -
Uses of MonitoredTask in org.apache.hadoop.hbase.master.snapshot
Fields in org.apache.hadoop.hbase.master.snapshot declared as MonitoredTask -
Uses of MonitoredTask in org.apache.hadoop.hbase.mob
Methods in org.apache.hadoop.hbase.mob with parameters of type MonitoredTaskModifier and TypeMethodDescriptionprotected voidDefaultMobStoreFlusher.finalizeWriter(StoreFileWriter writer, long cacheFlushSeqNum, MonitoredTask status) List<org.apache.hadoop.fs.Path>DefaultMobStoreFlusher.flushSnapshot(MemStoreSnapshot snapshot, long cacheFlushId, MonitoredTask status, ThroughputController throughputController, FlushLifeCycleTracker tracker, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) Flushes the snapshot of the MemStore.protected voidDefaultMobStoreFlusher.performMobFlush(MemStoreSnapshot snapshot, long cacheFlushId, InternalScanner scanner, StoreFileWriter writer, MonitoredTask status, ThroughputController throughputController, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) Flushes the cells in the mob store. -
Uses of MonitoredTask in org.apache.hadoop.hbase.monitoring
Subinterfaces of MonitoredTask in org.apache.hadoop.hbase.monitoringModifier and TypeInterfaceDescriptioninterfaceA MonitoredTask implementation optimized for use with RPC Handlers handling frequent, short duration tasks.Classes in org.apache.hadoop.hbase.monitoring that implement MonitoredTaskModifier and TypeClassDescriptionclassA MonitoredTask implementation designed for use with RPC Handlers handling frequent, short duration tasks.(package private) classclassTheTaskGroupcan be seen as a bigMonitoredTask, which contains a list of sub monitored tasks.Fields in org.apache.hadoop.hbase.monitoring declared as MonitoredTaskModifier and TypeFieldDescriptionprivate final MonitoredTaskTaskGroup.delegateUsed to track this task group inTaskMonitorprivate MonitoredTaskTaskMonitor.TaskAndWeakRefPair.implFields in org.apache.hadoop.hbase.monitoring with type parameters of type MonitoredTaskModifier and TypeFieldDescriptionprivate final ConcurrentLinkedDeque<MonitoredTask>TaskGroup.tasksSub-tasks in the groupprivate WeakReference<MonitoredTask>TaskMonitor.TaskAndWeakRefPair.weakProxyMethods in org.apache.hadoop.hbase.monitoring that return MonitoredTaskModifier and TypeMethodDescriptionAdd a new task to the group, and before that might complete the last task in the groupMonitoredTask.clone()Public exposure of Object.clone() in order to allow clients to easily capture current state.TaskMonitor.createStatus(String description) TaskMonitor.createStatus(String description, boolean ignore) TaskMonitor.createStatus(String description, boolean ignore, boolean enableJournal) Create a monitored task for users to inquire about the statusTaskMonitor.TaskAndWeakRefPair.get()Methods in org.apache.hadoop.hbase.monitoring that return types with arguments of type MonitoredTaskModifier and TypeMethodDescriptionTaskGroup.getTasks()TaskMonitor.getTasks()Produces a list containing copies of the current state of all non-expired MonitoredTasks handled by this TaskMonitor.Produces a list containing copies of the current state of all non-expired MonitoredTasks handled by this TaskMonitor.Methods in org.apache.hadoop.hbase.monitoring with parameters of type MonitoredTaskModifier and TypeMethodDescriptionprivate booleanTaskMonitor.canPurge(MonitoredTask stat) booleanTaskMonitor.TaskFilter.filter(MonitoredTask task) Filter out unwanted task.Method parameters in org.apache.hadoop.hbase.monitoring with type arguments of type MonitoredTaskModifier and TypeMethodDescriptionprivate static voidTaskMonitor.processTasks(Iterable<TaskMonitor.TaskAndWeakRefPair> tasks, TaskMonitor.TaskFilter filter, List<MonitoredTask> results) Constructors in org.apache.hadoop.hbase.monitoring with parameters of type MonitoredTask -
Uses of MonitoredTask in org.apache.hadoop.hbase.regionserver
Methods in org.apache.hadoop.hbase.regionserver with parameters of type MonitoredTaskModifier and TypeMethodDescriptionbooleanHStore.StoreFlusherImpl.commit(MonitoredTask status) booleanStoreFlushContext.commit(MonitoredTask status) Commit the flush - add the store file to the store and clear the memstore snapshot.private Map<byte[],List<HStoreFile>> HRegion.doClose(boolean abort, MonitoredTask status) protected voidStoreFlusher.finalizeWriter(StoreFileWriter writer, long cacheFlushSeqNum, MonitoredTask status) protected List<org.apache.hadoop.fs.Path>HStore.flushCache(long logCacheFlushId, MemStoreSnapshot snapshot, MonitoredTask status, ThroughputController throughputController, FlushLifeCycleTracker tracker, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) Write out current snapshot.voidHStore.StoreFlusherImpl.flushCache(MonitoredTask status) voidStoreFlushContext.flushCache(MonitoredTask status) Flush the cache (create the new store file) A length operation which doesn't require locking out any function of the store.List<org.apache.hadoop.fs.Path>DefaultStoreFlusher.flushSnapshot(MemStoreSnapshot snapshot, long cacheFlushId, MonitoredTask status, ThroughputController throughputController, FlushLifeCycleTracker tracker, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) abstract List<org.apache.hadoop.fs.Path>StoreFlusher.flushSnapshot(MemStoreSnapshot snapshot, long cacheFlushSeqNum, MonitoredTask status, ThroughputController throughputController, FlushLifeCycleTracker tracker, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) Turns a snapshot of memstore into a set of store files.List<org.apache.hadoop.fs.Path>StripeStoreFlusher.flushSnapshot(MemStoreSnapshot snapshot, long cacheFlushSeqNum, MonitoredTask status, ThroughputController throughputController, FlushLifeCycleTracker tracker, Consumer<org.apache.hadoop.fs.Path> writerCreationTracker) 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 HRegion.FlushResultImplHRegion.internalFlushcache(Collection<HStore> storesToFlush, MonitoredTask status, boolean writeFlushWalMarker, FlushLifeCycleTracker tracker) Flushing given stores.private HRegion.FlushResultHRegion.internalFlushcache(MonitoredTask status) Flushing all stores.protected HRegion.FlushResultImplHRegion.internalFlushcache(WAL wal, long myseqid, Collection<HStore> storesToFlush, MonitoredTask status, boolean writeFlushWalMarker, FlushLifeCycleTracker tracker) Flush the memstore.(package private) HRegion.FlushResultImplHRegion.internalFlushCacheAndCommit(WAL wal, MonitoredTask status, HRegion.PrepareFlushResult prepareResult, Collection<HStore> storesToFlush) protected HRegion.PrepareFlushResultHRegion.internalPrepareFlushCache(WAL wal, long myseqid, Collection<HStore> storesToFlush, MonitoredTask status, boolean writeFlushWalMarker, FlushLifeCycleTracker tracker) (package private) longHRegion.replayRecoveredEditsIfAny(Map<byte[], Long> maxSeqIdInStores, CancelableProgressable reporter, MonitoredTask status) Read the edits put under this region by wal splitting process. -
Uses of MonitoredTask in org.apache.hadoop.hbase.snapshot
Fields in org.apache.hadoop.hbase.snapshot declared as MonitoredTaskModifier and TypeFieldDescriptionprivate final MonitoredTaskRestoreSnapshotHelper.statusprivate final MonitoredTaskSnapshotManifest.statusTaskMethods in org.apache.hadoop.hbase.snapshot with parameters of type MonitoredTaskModifier and TypeMethodDescriptionstatic SnapshotManifestSnapshotManifest.create(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, org.apache.hadoop.fs.Path workingDir, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription desc, ForeignExceptionSnare monitor, MonitoredTask statusTask) Constructors in org.apache.hadoop.hbase.snapshot with parameters of type MonitoredTaskModifierConstructorDescriptionRestoreSnapshotHelper(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, SnapshotManifest manifest, TableDescriptor tableDescriptor, org.apache.hadoop.fs.Path rootDir, ForeignExceptionDispatcher monitor, MonitoredTask status) RestoreSnapshotHelper(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem fs, SnapshotManifest manifest, TableDescriptor tableDescriptor, org.apache.hadoop.fs.Path rootDir, ForeignExceptionDispatcher monitor, MonitoredTask status, boolean createBackRefs) privateSnapshotManifest(org.apache.hadoop.conf.Configuration conf, org.apache.hadoop.fs.FileSystem rootFs, org.apache.hadoop.fs.Path workingDir, org.apache.hadoop.hbase.shaded.protobuf.generated.SnapshotProtos.SnapshotDescription desc, ForeignExceptionSnare monitor, MonitoredTask statusTask) -
Uses of MonitoredTask in org.apache.hadoop.hbase.wal
Fields in org.apache.hadoop.hbase.wal declared as MonitoredTaskMethods in org.apache.hadoop.hbase.wal with parameters of type MonitoredTaskModifier and TypeMethodDescription(package private) voidOutputSink.setStatus(MonitoredTask status)