All Downloads are FREE. Search and download functionalities are using the official Maven repository.

alluxio.master.file.LostFileDetector Maven / Gradle / Ivy

/*
 * The Alluxio Open Foundation licenses this work under the Apache License, version 2.0
 * (the "License"). You may not use this work except in compliance with the License, which is
 * available at www.apache.org/licenses/LICENSE-2.0
 *
 * This software is distributed on an "AS IS" basis, WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND,
 * either express or implied, as more fully set forth in the License.
 *
 * See the NOTICE file distributed with this work for information regarding copyright ownership.
 */

package alluxio.master.file;

import alluxio.exception.FileDoesNotExistException;
import alluxio.exception.status.UnavailableException;
import alluxio.heartbeat.HeartbeatExecutor;
import alluxio.master.block.BlockId;
import alluxio.master.block.BlockMaster;
import alluxio.master.file.meta.Inode;
import alluxio.master.file.meta.InodeTree;
import alluxio.master.file.meta.InodeTree.LockPattern;
import alluxio.master.file.meta.LockedInodePath;
import alluxio.master.file.meta.PersistenceState;
import alluxio.master.journal.JournalContext;
import alluxio.master.journal.NoopJournalContext;
import alluxio.metrics.MetricKey;
import alluxio.metrics.MetricsSystem;
import alluxio.proto.journal.File.UpdateInodeEntry;
import alluxio.util.IdUtils;

import org.slf4j.Logger;
import org.slf4j.LoggerFactory;

import java.util.HashSet;
import java.util.Iterator;
import java.util.Set;
import javax.annotation.concurrent.NotThreadSafe;

/**
 * Lost files periodic check.
 */
@NotThreadSafe
final class LostFileDetector implements HeartbeatExecutor {
  private static final Logger LOG = LoggerFactory.getLogger(LostFileDetector.class);
  private final FileSystemMaster mFileSystemMaster;
  private final InodeTree mInodeTree;
  private final BlockMaster mBlockMaster;

  /**
   * Constructs a new {@link LostFileDetector}.
   */
  public LostFileDetector(FileSystemMaster fileSystemMaster, BlockMaster blockMaster,
      InodeTree inodeTree) {
    mFileSystemMaster = fileSystemMaster;
    mInodeTree = inodeTree;
    mBlockMaster = blockMaster;
    MetricsSystem.registerCachedGaugeIfAbsent(MetricKey.MASTER_LOST_FILE_COUNT.getName(),
        () -> mFileSystemMaster.getLostFiles().size());
  }

  @Override
  public void heartbeat(long timeLimitMs) throws InterruptedException {
    Iterator iter = mBlockMaster.getLostBlocksIterator();
    Set toMarkFiles = new HashSet<>();
    while (iter.hasNext()) {
      if (Thread.interrupted()) {
        throw new InterruptedException("LostFileDetector interrupted.");
      }
      long blockId = iter.next();
      long containerId = BlockId.getContainerId(blockId);
      long fileId = IdUtils.createFileId(containerId);
      if (toMarkFiles.contains(fileId)) {
        iter.remove();
        continue;
      }
      try (
          LockedInodePath inodePath =
              mInodeTree.lockFullInodePath(fileId, LockPattern.READ, NoopJournalContext.INSTANCE)
      ) {
        Inode inode = inodePath.getInode();
        if (inode.getPersistenceState() != PersistenceState.PERSISTED) {
          toMarkFiles.add(fileId);
        }
        iter.remove();
      } catch (FileDoesNotExistException e) {
        LOG.debug("Exception trying to get inode from inode tree", e);
        iter.remove();
        continue;
      }
    }

    if (toMarkFiles.size() > 0) {
      // Here the candidate block has been removed from the checklist
      // But the journal entries have not yet been flushed
      // If the journal entries are lost, we will never be able to mark them again,
      // because the worker will never report those removedBlocks to the master again
      // This is fine because the LOST status is purely for display now
      try (JournalContext journalContext = mFileSystemMaster.createJournalContext()) {
        // update the state on the 2nd pass
        for (long fileId : toMarkFiles) {
          try (LockedInodePath inodePath = mInodeTree.lockFullInodePath(
              fileId, LockPattern.WRITE_INODE, journalContext)) {
            Inode inode = inodePath.getInode();
            if (inode.getPersistenceState() != PersistenceState.PERSISTED) {
              mInodeTree.updateInode(journalContext,
                  UpdateInodeEntry.newBuilder().setId(inode.getId())
                      .setPersistenceState(PersistenceState.LOST.name()).build());
              toMarkFiles.add(fileId);
            }
          } catch (FileDoesNotExistException e) {
            LOG.debug("Failed to mark file {} as lost. The inode does not exist anymore.",
                fileId, e);
          }
        }
      } catch (UnavailableException e) {
        LOG.error("Failed to mark files LOST because the journal is not available. "
            + "{} files are affected: {}", toMarkFiles.size(), toMarkFiles, e);
      }
    }
  }

  @Override
  public void close() {
    // Nothing to clean up
  }
}




© 2015 - 2025 Weber Informatics LLC | Privacy Policy