| Modifier and Type | Method and Description | 
|---|---|
| (package private) boolean | ActiveMasterManager. blockUntilBecomingActiveMaster(int checkInterval,
                              MonitoredTask startupStatus)Block until becoming the active master. | 
| private void | HMaster. finishActiveMasterInitialization(MonitoredTask status)Finish initialization of HMaster after becoming the primary master. | 
| private void | HMaster. waitForRegionServers(MonitoredTask status) | 
| void | ServerManager. waitForRegionServers(MonitoredTask status)Wait for the region servers to report in. | 
| private void | SplitLogManager. waitForSplittingCompletion(SplitLogManager.TaskBatch batch,
                          MonitoredTask status)Deprecated.  | 
| Modifier and Type | Field and Description | 
|---|---|
| private MonitoredTask | CloneSnapshotProcedure. monitorStatus | 
| private MonitoredTask | RestoreSnapshotProcedure. monitorStatus | 
| private MonitoredTask | ServerCrashProcedure. status | 
| Modifier and Type | Method and Description | 
|---|---|
| private MonitoredTask | CloneSnapshotProcedure. getMonitorStatus()Set up monitor status if it is not created. | 
| private MonitoredTask | RestoreSnapshotProcedure. getMonitorStatus()Set up monitor status if it is not created. | 
| Modifier and Type | Field and Description | 
|---|---|
| protected MonitoredTask | TakeSnapshotHandler. status | 
| Modifier and Type | Method and Description | 
|---|---|
| List<org.apache.hadoop.fs.Path> | DefaultMobStoreFlusher. flushSnapshot(MemStoreSnapshot snapshot,
             long cacheFlushId,
             MonitoredTask status,
             ThroughputController throughputController,
             FlushLifeCycleTracker tracker)Flushes the snapshot of the MemStore. | 
| protected void | DefaultMobStoreFlusher. performMobFlush(MemStoreSnapshot snapshot,
               long cacheFlushId,
               InternalScanner scanner,
               StoreFileWriter writer,
               MonitoredTask status,
               ThroughputController throughputController)Flushes the cells in the mob store. | 
| Modifier and Type | Interface and Description | 
|---|---|
| interface  | MonitoredRPCHandlerA MonitoredTask implementation optimized for use with RPC Handlers 
 handling frequent, short duration tasks. | 
| Modifier and Type | Class and Description | 
|---|---|
| class  | MonitoredRPCHandlerImplA MonitoredTask implementation designed for use with RPC Handlers 
 handling frequent, short duration tasks. | 
| (package private) class  | MonitoredTaskImpl | 
| Modifier and Type | Field and Description | 
|---|---|
| private MonitoredTask | TaskMonitor.TaskAndWeakRefPair. impl | 
| Modifier and Type | Field and Description | 
|---|---|
| private WeakReference<MonitoredTask> | TaskMonitor.TaskAndWeakRefPair. weakProxy | 
| Modifier and Type | Method and Description | 
|---|---|
| MonitoredTask | MonitoredTask. clone()Public exposure of Object.clone() in order to allow clients to easily 
 capture current state. | 
| MonitoredTask | TaskMonitor. createStatus(String description) | 
| MonitoredTask | TaskMonitor.TaskAndWeakRefPair. get() | 
| Modifier and Type | Method and Description | 
|---|---|
| List<MonitoredTask> | TaskMonitor. getTasks()Produces a list containing copies of the current state of all non-expired 
 MonitoredTasks handled by this TaskMonitor. | 
| List<MonitoredTask> | TaskMonitor. getTasks(String filter)Produces a list containing copies of the current state of all non-expired 
 MonitoredTasks handled by this TaskMonitor. | 
| Modifier and Type | Method and Description | 
|---|---|
| private boolean | TaskMonitor. canPurge(MonitoredTask stat) | 
| boolean | TaskMonitor.TaskFilter. filter(MonitoredTask task)Filter out unwanted task. | 
| Modifier and Type | Method and Description | 
|---|---|
| private static void | TaskMonitor. processTasks(Iterable<TaskMonitor.TaskAndWeakRefPair> tasks,
            TaskMonitor.TaskFilter filter,
            List<MonitoredTask> results) | 
| Constructor and Description | 
|---|
| TaskAndWeakRefPair(MonitoredTask stat,
                  MonitoredTask proxy) | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | HStore.StoreFlusherImpl. commit(MonitoredTask status) | 
| boolean | StoreFlushContext. commit(MonitoredTask status)Commit the flush - add the store file to the store and clear the
 memstore snapshot. | 
| private HStoreFile | HStore. commitFile(org.apache.hadoop.fs.Path path,
          long logCacheFlushId,
          MonitoredTask status) | 
| private Map<byte[],List<HStoreFile>> | HRegion. doClose(boolean abort,
       MonitoredTask status) | 
| protected void | StoreFlusher. 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)Write out current snapshot. | 
| void | HStore.StoreFlusherImpl. flushCache(MonitoredTask status) | 
| void | StoreFlushContext. 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) | 
| abstract List<org.apache.hadoop.fs.Path> | StoreFlusher. flushSnapshot(MemStoreSnapshot snapshot,
             long cacheFlushSeqNum,
             MonitoredTask status,
             ThroughputController throughputController,
             FlushLifeCycleTracker tracker)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) | 
| private long | HRegion. initializeRegionInternals(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 HRegion.FlushResultImpl | HRegion. internalFlushcache(Collection<HStore> storesToFlush,
                  MonitoredTask status,
                  boolean writeFlushWalMarker,
                  FlushLifeCycleTracker tracker)Flushing given stores. | 
| private HRegion.FlushResult | HRegion. internalFlushcache(MonitoredTask status)Flushing all stores. | 
| protected HRegion.FlushResultImpl | HRegion. internalFlushcache(WAL wal,
                  long myseqid,
                  Collection<HStore> storesToFlush,
                  MonitoredTask status,
                  boolean writeFlushWalMarker,
                  FlushLifeCycleTracker tracker)Flush the memstore. | 
| protected HRegion.FlushResultImpl | HRegion. internalFlushCacheAndCommit(WAL wal,
                           MonitoredTask status,
                           HRegion.PrepareFlushResult prepareResult,
                           Collection<HStore> storesToFlush) | 
| protected HRegion.PrepareFlushResult | HRegion. internalPrepareFlushCache(WAL wal,
                         long myseqid,
                         Collection<HStore> storesToFlush,
                         MonitoredTask status,
                         boolean writeFlushWalMarker,
                         FlushLifeCycleTracker tracker) | 
| (package private) long | HRegion. replayRecoveredEditsIfAny(Map<byte[],Long> maxSeqIdInStores,
                         CancelableProgressable reporter,
                         MonitoredTask status)Read the edits put under this region by wal splitting process. | 
| Modifier and Type | Field and Description | 
|---|---|
| private MonitoredTask | RestoreSnapshotHelper. status | 
| private MonitoredTask | SnapshotManifest. statusTask | 
| Modifier and Type | Method and Description | 
|---|---|
| static SnapshotManifest | SnapshotManifest. 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) | 
| Constructor and Description | 
|---|
| 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) | 
| 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) | 
| SnapshotManifest(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) | 
| Modifier and Type | Field and Description | 
|---|---|
| protected MonitoredTask | OutputSink. status | 
| Modifier and Type | Method and Description | 
|---|---|
| (package private) void | OutputSink. setStatus(MonitoredTask status) | 
Copyright © 2007–2021 The Apache Software Foundation. All rights reserved.