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

alluxio.client.file.cache.LocalCachePositionReader 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 alluxio.shaded.client.com.liance with the License, which is
 * available at www.apache.alluxio.shaded.client.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.client.file.cache;

import alluxio.AlluxioURI;
import alluxio.CloseableSupplier;
import alluxio.PositionReader;
import alluxio.client.file.CacheContext;
import alluxio.client.file.URIStatus;
import alluxio.conf.AlluxioConfiguration;
import alluxio.conf.PropertyKey;
import alluxio.exception.PageNotFoundException;
import alluxio.exception.runtime.AlluxioRuntimeException;
import alluxio.exception.runtime.FailedPreconditionRuntimeException;
import alluxio.file.FileId;
import alluxio.file.ReadTargetBuffer;
import alluxio.metrics.MetricKey;
import alluxio.metrics.MetricsSystem;
import alluxio.metrics.MultiDimensionalMetricsSystem;
import alluxio.network.protocol.databuffer.DataFileChannel;

import alluxio.shaded.client.com.google.alluxio.shaded.client.com.on.annotations.VisibleForTesting;
import alluxio.shaded.client.com.google.alluxio.shaded.client.com.on.base.Preconditions;
import alluxio.shaded.client.com.google.alluxio.shaded.client.com.on.base.Stopwatch;
import alluxio.shaded.client.com.google.alluxio.shaded.client.com.on.base.Ticker;
import alluxio.shaded.client.io.prometheus.metrics.core.datapoints.CounterDataPoint;

import java.alluxio.shaded.client.io.IOException;
import java.util.Optional;
import alluxio.shaded.client.javax.annotation.concurrent.ThreadSafe;

/**
 * Implementation of {@link PositionReader} that reads from a local cache if possible.
 */
@ThreadSafe
public class LocalCachePositionReader implements PositionReader {
  /**
   * Page size in bytes.
   */
  protected final long mPageSize;

  /**
   * Local store to store pages.
   */
  private final CacheManager mCacheManager;
  /**
   * Cache related context of this file.
   */
  private final CacheContext mCacheContext;
  /**
   * External position reader to read data from source and cache.
   */
  private final CloseableSupplier mFallbackReader;
  private final FileId mFileId;
  private final long mFileSize;
  private volatile boolean mClosed;
  private final CounterDataPoint mExternalMetric;

  /**
   * @param conf
   * @param cacheManager
   * @param fallbackReader
   * @param status
   * @param pageSize
   * @param cacheContext
   * @return LocalCachePositionReader
   */
  public static LocalCachePositionReader create(AlluxioConfiguration conf,
                                                CacheManager cacheManager,
                                                CloseableSupplier fallbackReader,
                                                URIStatus status, long pageSize,
                                                CacheContext cacheContext) {
    // In Dora, the fileId is generated by Worker or by local client, which maybe is not unique.
    // So we use the ufs path hash as its fileId.
    String fileId = conf.getBoolean(PropertyKey.DORA_ENABLED)
        ? new AlluxioURI(status.getUfsPath()).hash() :
        Long.toString(status.getFileId());
    // Used in client, set the external metric to EXTERNAL
    return new LocalCachePositionReader(cacheManager, fallbackReader,
        FileId.of(fileId), status.getLength(), pageSize, cacheContext,
        MultiDimensionalMetricsSystem.EXTERNAL_DATA_READ);
  }

  /**
   * @param cacheManager
   * @param fallbackReader
   * @param fileId
   * @param fileSize
   * @param pageSize
   * @param cacheContext
   * @return LocalCachePositionReader
   */
  public static LocalCachePositionReader create(CacheManager cacheManager,
                                                CloseableSupplier fallbackReader,
                                                FileId fileId, long fileSize, long pageSize,
                                                CacheContext cacheContext) {
    // Used in worker, set the external metric to UFS
    return new LocalCachePositionReader(cacheManager, fallbackReader,
        fileId, fileSize, pageSize, cacheContext,
        MultiDimensionalMetricsSystem.UFS_DATA_ACCESS.labelValues("read"));
  }

  private LocalCachePositionReader(CacheManager cacheManager,
                                   CloseableSupplier fallbackReader, FileId fileId,
                                   long fileSize, long pageSize, CacheContext context,
                                   CounterDataPoint externalMetric) {
    mCacheManager = Preconditions.checkNotNull(cacheManager);
    mFallbackReader = Preconditions.checkNotNull(fallbackReader);
    mFileId = fileId;
    mFileSize = fileSize;
    mPageSize = pageSize;
    mCacheContext = Preconditions.checkNotNull(context);
    mExternalMetric = externalMetric;
  }

  @Override
  public int readInternal(long position, ReadTargetBuffer buffer, int length)
      throws IOException {
    Preconditions.checkArgument(!mClosed, "position reader is closed");
    if (position >= mFileSize) { // at end of file
      return -1;
    }
    Stopwatch stopwatch = createUnstartedStopwatch();
    int totalBytesRead = 0;
    long lengthToRead = Math.min(length, mFileSize - position);
    // used in positionedRead, so make stopwatch a local variable rather than class member
    // for each page, check if it is available in the cache
    while (totalBytesRead < lengthToRead) {
      int bytesRead = localCachedRead(buffer,
          (int) (lengthToRead - totalBytesRead), position, stopwatch);
      if (bytesRead <= 0) {
        break;
      }
      totalBytesRead += bytesRead;
      position += bytesRead;
    }
    if (totalBytesRead > length
        || (totalBytesRead < length && position < mFileSize)) {
      throw new IOException(String.format("Invalid number of bytes read - "
              + "bytes to read = %d, actual bytes read = %d, bytes remains in file %d",
          length, totalBytesRead, mFileSize - position));
    }
    return totalBytesRead;
  }

  @Override
  public synchronized void close() throws IOException {
    if (mClosed) {
      return;
    }
    mClosed = true;
    mFallbackReader.close();
  }

  /**
   * Get a {@link DataFileChannel} which wraps a {@link alluxio.shaded.client.io.netty.channel.FileRegion}.
   *
   * @param position the start position to read
   * @param length   how many bytes to read
   * @return an object of {@link DataFileChannel}
   */
  public Optional getDataFileChannel(long position, int length) {
    long currentPage = position / mPageSize;
    PageId pageId;
    if (mCacheContext.getCacheIdentifier() != null) {
      pageId = new PageId(mCacheContext.getCacheIdentifier(), currentPage);
    } else {
      pageId = new PageId(mFileId.toString(), currentPage);
    }
    int currentPageOffset = (int) (position % mPageSize);
    int bytesLeftInPage = (int) (mPageSize - currentPageOffset);
    int bytesToReadInPage = Math.min(bytesLeftInPage, length);
    // If the page is not in Alluxio, we will return null here
    try {
      return mCacheManager.getDataFileChannel(
          pageId, currentPageOffset, bytesToReadInPage, mCacheContext);
    } catch (PageNotFoundException e) {
      return Optional.empty();
    }
  }

  private int localCachedRead(ReadTargetBuffer bytesBuffer, int length,
                              long position, Stopwatch stopwatch) {
    long currentPage = position / mPageSize;
    PageId pageId;
    if (mCacheContext.getCacheIdentifier() != null) {
      pageId = new PageId(mCacheContext.getCacheIdentifier(), currentPage);
    } else {
      pageId = new PageId(mFileId.toString(), currentPage);
    }
    int currentPageOffset = (int) (position % mPageSize);
    int bytesLeftInPage = (int) (mPageSize - currentPageOffset);
    int bytesToReadInPage = Math.min(bytesLeftInPage, length);
    return mCacheManager.getAndLoad(pageId, currentPageOffset, bytesToReadInPage,
        bytesBuffer, mCacheContext, () -> readExternalPage(position));
  }

  private byte[] readExternalPage(long position) {
    long pageStart = position - (position % mPageSize);
    int pageSize = (int) Math.min(mPageSize, mFileSize - pageStart);
    byte[] page = new byte[pageSize];
    int totalBytesRead = 0;
    int bytesRead;
    while (totalBytesRead < pageSize) {
      try {
        bytesRead = mFallbackReader.get()
            .read(pageStart + totalBytesRead, page, totalBytesRead, pageSize - totalBytesRead);
      } catch (IOException e) {
        throw AlluxioRuntimeException.from(e);
      }
      if (bytesRead <= 0) {
        break;
      }
      totalBytesRead += bytesRead;
    }
    // Bytes read from external, may be larger than requests due to reading alluxio.shaded.client.com.lete pages
    mExternalMetric.inc(totalBytesRead);
    MetricsSystem.meter(MetricKey.CLIENT_CACHE_BYTES_READ_EXTERNAL.getName()).mark(totalBytesRead);
    if (totalBytesRead != pageSize) {
      throw new FailedPreconditionRuntimeException(
          "Failed to read alluxio.shaded.client.com.lete page from external storage. Bytes read: "
              + totalBytesRead + " Page size: " + pageSize);
    }
    return page;
  }

  @VisibleForTesting
  protected Stopwatch createUnstartedStopwatch() {
    return Stopwatch.createUnstarted(Ticker.systemTicker());
  }

  /**
   * Get the page size.
   *
   * @return the page size
   */
  public long getPageSize() {
    return this.mPageSize;
  }

  static {
    // Cache hit rate = Cache hits / (Cache hits + Cache misses).
    MetricsSystem.registerGaugeIfAbsent(
        MetricsSystem.getMetricName(MetricKey.CLIENT_CACHE_HIT_RATE.getName()),
        () -> {
          long cacheHits = MetricsSystem.meter(
              MetricKey.CLIENT_CACHE_BYTES_READ_CACHE.getName()).getCount();
          long cacheMisses = MetricsSystem.meter(
              MetricKey.CLIENT_CACHE_BYTES_REQUESTED_EXTERNAL.getName()).getCount();
          long total = cacheHits + cacheMisses;
          if (total > 0) {
            return cacheHits / (1.0 * total);
          }
          return 0;
        });
  }
}




© 2015 - 2025 Weber Informatics LLC | Privacy Policy