Ver Fonte

HDFS-2465. Backporting from trunk - Add HDFS support for fadvise readahead and drop-behind. Contributed by Todd Lipcon. Backported by Brandon Li.

git-svn-id: https://svn.apache.org/repos/asf/hadoop/common/branches/branch-1.1@1362670 13f79535-47bb-0310-9956-ffa450edef68
Suresh Srinivas há 13 anos atrás
pai
commit
41621bac8b

+ 8 - 5
CHANGES.txt

@@ -8,13 +8,8 @@ Release 1.1.1 - Unreleased
 
 
   IMPROVEMENTS
   IMPROVEMENTS
 
 
-    HADOOP-7753. Support fadvise and sync_file_range in NativeIO. Add
-    ReadaheadPool infrastructure for use in HDFS and MR.
-    (Brandon Li and todd via suresh)
-
   BUG FIXES
   BUG FIXES
 
 
-
 Release 1.1.0 - 2012.07.09
 Release 1.1.0 - 2012.07.09
 
 
   INCOMPATIBLE CHANGES
   INCOMPATIBLE CHANGES
@@ -132,6 +127,14 @@ Release 1.1.0 - 2012.07.09
 
 
     HDFS-3516. Check content-type in WebHdfsFileSystem.  (szetszwo)
     HDFS-3516. Check content-type in WebHdfsFileSystem.  (szetszwo)
 
 
+    HADOOP-7753. Support fadvise and sync_file_range in NativeIO. Add
+    ReadaheadPool infrastructure for use in HDFS and MR.
+    (Brandon Li and todd via suresh)
+
+    HDFS-2465. Add HDFS support for fadvise readahead and drop-behind.
+    (todd via suresh)
+
+
   BUG FIXES
   BUG FIXES
 
 
     MAPREDUCE-4087. [Gridmix] GenerateDistCacheData job of Gridmix can
     MAPREDUCE-4087. [Gridmix] GenerateDistCacheData job of Gridmix can

+ 9 - 0
src/hdfs/org/apache/hadoop/hdfs/DFSConfigKeys.java

@@ -52,6 +52,15 @@ public class DFSConfigKeys extends CommonConfigurationKeys {
   public static final String  DFS_NAMENODE_BACKUP_SERVICE_RPC_ADDRESS_KEY = "dfs.namenode.backup.dnrpc-address";
   public static final String  DFS_NAMENODE_BACKUP_SERVICE_RPC_ADDRESS_KEY = "dfs.namenode.backup.dnrpc-address";
   public static final String  DFS_DATANODE_BALANCE_BANDWIDTHPERSEC_KEY = "dfs.datanode.balance.bandwidthPerSec";
   public static final String  DFS_DATANODE_BALANCE_BANDWIDTHPERSEC_KEY = "dfs.datanode.balance.bandwidthPerSec";
   public static final long    DFS_DATANODE_BALANCE_BANDWIDTHPERSEC_DEFAULT = 1024*1024;
   public static final long    DFS_DATANODE_BALANCE_BANDWIDTHPERSEC_DEFAULT = 1024*1024;
+  public static final String  DFS_DATANODE_READAHEAD_BYTES_KEY = "dfs.datanode.readahead.bytes";
+  public static final long    DFS_DATANODE_READAHEAD_BYTES_DEFAULT = 0;
+  public static final String  DFS_DATANODE_DROP_CACHE_BEHIND_WRITES_KEY = "dfs.datanode.drop.cache.behind.writes";
+  public static final boolean DFS_DATANODE_DROP_CACHE_BEHIND_WRITES_DEFAULT = false;
+  public static final String  DFS_DATANODE_SYNC_BEHIND_WRITES_KEY = "dfs.datanode.sync.behind.writes";
+  public static final boolean DFS_DATANODE_SYNC_BEHIND_WRITES_DEFAULT = false;
+  public static final String  DFS_DATANODE_DROP_CACHE_BEHIND_READS_KEY = "dfs.datanode.drop.cache.behind.reads";
+  public static final boolean DFS_DATANODE_DROP_CACHE_BEHIND_READS_DEFAULT = false;
+  
   public static final String  DFS_NAMENODE_HTTP_PORT_KEY = "dfs.http.port";
   public static final String  DFS_NAMENODE_HTTP_PORT_KEY = "dfs.http.port";
   public static final int     DFS_NAMENODE_HTTP_PORT_DEFAULT = 50070;
   public static final int     DFS_NAMENODE_HTTP_PORT_DEFAULT = 50070;
   public static final String  DFS_NAMENODE_HTTP_ADDRESS_KEY = "dfs.namenode.http-address";
   public static final String  DFS_NAMENODE_HTTP_ADDRESS_KEY = "dfs.namenode.http-address";

+ 42 - 1
src/hdfs/org/apache/hadoop/hdfs/server/datanode/BlockReceiver.java

@@ -21,6 +21,8 @@ import java.io.BufferedOutputStream;
 import java.io.DataInputStream;
 import java.io.DataInputStream;
 import java.io.DataOutputStream;
 import java.io.DataOutputStream;
 import java.io.EOFException;
 import java.io.EOFException;
+import java.io.FileDescriptor;
+import java.io.FileOutputStream;
 import java.io.IOException;
 import java.io.IOException;
 import java.io.OutputStream;
 import java.io.OutputStream;
 import java.nio.ByteBuffer;
 import java.nio.ByteBuffer;
@@ -38,6 +40,7 @@ import org.apache.hadoop.hdfs.protocol.FSConstants;
 import org.apache.hadoop.hdfs.protocol.LocatedBlock;
 import org.apache.hadoop.hdfs.protocol.LocatedBlock;
 import org.apache.hadoop.hdfs.protocol.DataTransferProtocol.PipelineAck;
 import org.apache.hadoop.hdfs.protocol.DataTransferProtocol.PipelineAck;
 import org.apache.hadoop.io.IOUtils;
 import org.apache.hadoop.io.IOUtils;
+import org.apache.hadoop.io.nativeio.NativeIO;
 import org.apache.hadoop.util.Daemon;
 import org.apache.hadoop.util.Daemon;
 import org.apache.hadoop.util.DataChecksum;
 import org.apache.hadoop.util.DataChecksum;
 import org.apache.hadoop.util.StringUtils;
 import org.apache.hadoop.util.StringUtils;
@@ -51,11 +54,14 @@ class BlockReceiver implements java.io.Closeable, FSConstants {
   public static final Log LOG = DataNode.LOG;
   public static final Log LOG = DataNode.LOG;
   static final Log ClientTraceLog = DataNode.ClientTraceLog;
   static final Log ClientTraceLog = DataNode.ClientTraceLog;
   
   
+  private static final long CACHE_DROP_LAG_BYTES = 8 * 1024 * 1024;
+  
   private Block block; // the block to receive
   private Block block; // the block to receive
   protected boolean finalized;
   protected boolean finalized;
   private DataInputStream in = null; // from where data are read
   private DataInputStream in = null; // from where data are read
   private DataChecksum checksum; // from where chunks of a block can be read
   private DataChecksum checksum; // from where chunks of a block can be read
   private OutputStream out = null; // to block file at local disk
   private OutputStream out = null; // to block file at local disk
+  private FileDescriptor outFd;
   private DataOutputStream checksumOut = null; // to crc file at local disk
   private DataOutputStream checksumOut = null; // to crc file at local disk
   private int bytesPerChecksum;
   private int bytesPerChecksum;
   private int checksumSize;
   private int checksumSize;
@@ -77,6 +83,11 @@ class BlockReceiver implements java.io.Closeable, FSConstants {
   private DataNode datanode = null;
   private DataNode datanode = null;
   volatile private boolean mirrorError;
   volatile private boolean mirrorError;
 
 
+  // Cache management state
+  private boolean dropCacheBehindWrites;
+  private boolean syncBehindWrites;
+  private long lastCacheDropOffset = 0;
+  
   BlockReceiver(Block block, DataInputStream in, String inAddr,
   BlockReceiver(Block block, DataInputStream in, String inAddr,
                 String myAddr, boolean isRecovery, String clientName, 
                 String myAddr, boolean isRecovery, String clientName, 
                 DatanodeInfo srcDataNode, DataNode datanode) throws IOException {
                 DatanodeInfo srcDataNode, DataNode datanode) throws IOException {
@@ -93,6 +104,8 @@ class BlockReceiver implements java.io.Closeable, FSConstants {
       this.checksum = DataChecksum.newDataChecksum(in);
       this.checksum = DataChecksum.newDataChecksum(in);
       this.bytesPerChecksum = checksum.getBytesPerChecksum();
       this.bytesPerChecksum = checksum.getBytesPerChecksum();
       this.checksumSize = checksum.getChecksumSize();
       this.checksumSize = checksum.getChecksumSize();
+      this.dropCacheBehindWrites = datanode.shouldDropCacheBehindWrites();
+      this.syncBehindWrites = datanode.shouldSyncBehindWrites();
       //
       //
       // Open local disk out
       // Open local disk out
       //
       //
@@ -101,6 +114,12 @@ class BlockReceiver implements java.io.Closeable, FSConstants {
       this.finalized = false;
       this.finalized = false;
       if (streams != null) {
       if (streams != null) {
         this.out = streams.dataOut;
         this.out = streams.dataOut;
+        if (out instanceof FileOutputStream) {
+          this.outFd = ((FileOutputStream) out).getFD();
+        } else {
+          LOG.warn("Could not get file descriptor for outputstream of class "
+              + out.getClass());
+        }
         this.checksumOut = new DataOutputStream(new BufferedOutputStream(
         this.checksumOut = new DataOutputStream(new BufferedOutputStream(
                                                   streams.checksumOut, 
                                                   streams.checksumOut, 
                                                   SMALL_BUFFER_SIZE));
                                                   SMALL_BUFFER_SIZE));
@@ -471,12 +490,12 @@ class BlockReceiver implements java.io.Closeable, FSConstants {
             checksumOut.write(pktBuf, checksumOff, checksumLen);
             checksumOut.write(pktBuf, checksumOff, checksumLen);
           }
           }
           datanode.myMetrics.incrBytesWritten(len);
           datanode.myMetrics.incrBytesWritten(len);
-
           /// flush entire packet before sending ack
           /// flush entire packet before sending ack
           flush();
           flush();
           
           
           // update length only after flush to disk
           // update length only after flush to disk
           datanode.data.setVisibleLength(block, offsetInBlock);
           datanode.data.setVisibleLength(block, offsetInBlock);
+          dropOsCacheBehindWriter(offsetInBlock);
         }
         }
       } catch (IOException iex) {
       } catch (IOException iex) {
         datanode.checkDiskError(iex);
         datanode.checkDiskError(iex);
@@ -497,6 +516,28 @@ class BlockReceiver implements java.io.Closeable, FSConstants {
     return payloadLen;
     return payloadLen;
   }
   }
 
 
+  private void dropOsCacheBehindWriter(long offsetInBlock) throws IOException {
+    try {
+      if (outFd != null
+          && offsetInBlock > lastCacheDropOffset + CACHE_DROP_LAG_BYTES) {
+        long twoWindowsAgo = lastCacheDropOffset - CACHE_DROP_LAG_BYTES;
+        if (twoWindowsAgo > 0 && dropCacheBehindWrites) {
+          NativeIO.posixFadviseIfPossible(outFd, 0, lastCacheDropOffset,
+              NativeIO.POSIX_FADV_DONTNEED);
+        }
+
+        if (syncBehindWrites) {
+          NativeIO.syncFileRangeIfPossible(outFd, lastCacheDropOffset,
+              CACHE_DROP_LAG_BYTES, NativeIO.SYNC_FILE_RANGE_WRITE);
+        }
+
+        lastCacheDropOffset += CACHE_DROP_LAG_BYTES;
+      }
+    } catch (Throwable t) {
+      LOG.warn("Couldn't drop os cache behind writer for " + block, t);
+    }
+  }
+
   void writeChecksumHeader(DataOutputStream mirrorOut) throws IOException {
   void writeChecksumHeader(DataOutputStream mirrorOut) throws IOException {
     checksum.writeHeader(mirrorOut);
     checksum.writeHeader(mirrorOut);
   }
   }

+ 89 - 2
src/hdfs/org/apache/hadoop/hdfs/server/datanode/BlockSender.java

@@ -20,6 +20,7 @@ package org.apache.hadoop.hdfs.server.datanode;
 import java.io.BufferedInputStream;
 import java.io.BufferedInputStream;
 import java.io.DataInputStream;
 import java.io.DataInputStream;
 import java.io.DataOutputStream;
 import java.io.DataOutputStream;
+import java.io.FileDescriptor;
 import java.io.FileInputStream;
 import java.io.FileInputStream;
 import java.io.IOException;
 import java.io.IOException;
 import java.io.InputStream;
 import java.io.InputStream;
@@ -34,6 +35,9 @@ import org.apache.hadoop.fs.ChecksumException;
 import org.apache.hadoop.hdfs.protocol.Block;
 import org.apache.hadoop.hdfs.protocol.Block;
 import org.apache.hadoop.hdfs.protocol.FSConstants;
 import org.apache.hadoop.hdfs.protocol.FSConstants;
 import org.apache.hadoop.io.IOUtils;
 import org.apache.hadoop.io.IOUtils;
+import org.apache.hadoop.io.ReadaheadPool;
+import org.apache.hadoop.io.ReadaheadPool.ReadaheadRequest;
+import org.apache.hadoop.io.nativeio.NativeIO;
 import org.apache.hadoop.net.SocketOutputStream;
 import org.apache.hadoop.net.SocketOutputStream;
 import org.apache.hadoop.util.ChecksumUtil;
 import org.apache.hadoop.util.ChecksumUtil;
 import org.apache.hadoop.util.DataChecksum;
 import org.apache.hadoop.util.DataChecksum;
@@ -51,6 +55,7 @@ class BlockSender implements java.io.Closeable, FSConstants {
   private long blockInPosition = -1; // updated while using transferTo().
   private long blockInPosition = -1; // updated while using transferTo().
   private DataInputStream checksumIn; // checksum datastream
   private DataInputStream checksumIn; // checksum datastream
   private DataChecksum checksum; // checksum stream
   private DataChecksum checksum; // checksum stream
+  private long initialOffset; // initial position to read
   private long offset; // starting position to read
   private long offset; // starting position to read
   private long endOffset; // ending position
   private long endOffset; // ending position
   private long blockLength;
   private long blockLength;
@@ -74,6 +79,22 @@ class BlockSender implements java.io.Closeable, FSConstants {
    */
    */
   private static final int MIN_BUFFER_WITH_TRANSFERTO = 64*1024;
   private static final int MIN_BUFFER_WITH_TRANSFERTO = 64*1024;
 
 
+  /** The file descriptor of the block being sent */
+  private FileDescriptor blockInFd;
+
+  // Cache-management related fields
+  private final long readaheadLength;
+  private boolean shouldDropCacheBehindRead;
+  private ReadaheadRequest curReadahead;
+  private long lastCacheDropOffset;
+  private static final long CACHE_DROP_INTERVAL_BYTES = 1024 * 1024; // 1MB
+  /**
+   * Minimum length of read below which management of the OS buffer cache is
+   * disabled.
+   */
+  private static final long LONG_READ_THRESHOLD_BYTES = 256 * 1024;
+
+  private static ReadaheadPool readaheadPool = ReadaheadPool.getInstance();
   
   
   BlockSender(Block block, long startOffset, long length,
   BlockSender(Block block, long startOffset, long length,
               boolean corruptChecksumOk, boolean chunkOffsetOK,
               boolean corruptChecksumOk, boolean chunkOffsetOK,
@@ -94,7 +115,9 @@ class BlockSender implements java.io.Closeable, FSConstants {
       this.blockLength = datanode.data.getVisibleLength(block);
       this.blockLength = datanode.data.getVisibleLength(block);
       this.transferToAllowed = datanode.transferToAllowed;
       this.transferToAllowed = datanode.transferToAllowed;
       this.clientTraceFmt = clientTraceFmt;
       this.clientTraceFmt = clientTraceFmt;
-
+      this.readaheadLength = datanode.getReadaheadLength();
+      this.shouldDropCacheBehindRead = datanode.shouldDropCacheBehindReads();
+      
       if ( !corruptChecksumOk || datanode.data.metaFileExists(block) ) {
       if ( !corruptChecksumOk || datanode.data.metaFileExists(block) ) {
         checksumIn = new DataInputStream(
         checksumIn = new DataInputStream(
                 new BufferedInputStream(datanode.data.getMetaDataInputStream(block),
                 new BufferedInputStream(datanode.data.getMetaDataInputStream(block),
@@ -166,6 +189,11 @@ class BlockSender implements java.io.Closeable, FSConstants {
       seqno = 0;
       seqno = 0;
 
 
       blockIn = datanode.data.getBlockInputStream(block, offset); // seek to offset
       blockIn = datanode.data.getBlockInputStream(block, offset); // seek to offset
+      if (blockIn instanceof FileInputStream) {
+        blockInFd = ((FileInputStream) blockIn).getFD();
+      } else {
+        blockInFd = null;
+      }
       memoizedBlock = new MemoizedBlock(blockIn, blockLength, datanode.data, block);
       memoizedBlock = new MemoizedBlock(blockIn, blockLength, datanode.data, block);
     } catch (IOException ioe) {
     } catch (IOException ioe) {
       IOUtils.closeStream(this);
       IOUtils.closeStream(this);
@@ -178,6 +206,19 @@ class BlockSender implements java.io.Closeable, FSConstants {
    * close opened files.
    * close opened files.
    */
    */
   public void close() throws IOException {
   public void close() throws IOException {
+    if (blockInFd != null && shouldDropCacheBehindRead) {
+      // drop the last few MB of the file from cache
+      try {
+        NativeIO.posixFadviseIfPossible(blockInFd, lastCacheDropOffset, offset
+            - lastCacheDropOffset, NativeIO.POSIX_FADV_DONTNEED);
+      } catch (Exception e) {
+        LOG.warn("Unable to drop cache on file close", e);
+      }
+    }
+    if (curReadahead != null) {
+      curReadahead.cancel();
+    }
+  
     IOException ioe = null;
     IOException ioe = null;
     // close checksum file
     // close checksum file
     if(checksumIn!=null) {
     if(checksumIn!=null) {
@@ -196,6 +237,7 @@ class BlockSender implements java.io.Closeable, FSConstants {
         ioe = e;
         ioe = e;
       }
       }
       blockIn = null;
       blockIn = null;
+      blockInFd = null;
     }
     }
     // throw IOException if there is any
     // throw IOException if there is any
     if(ioe!= null) {
     if(ioe!= null) {
@@ -387,10 +429,21 @@ class BlockSender implements java.io.Closeable, FSConstants {
     }
     }
     this.throttler = throttler;
     this.throttler = throttler;
 
 
-    long initialOffset = offset;
+    initialOffset = offset;
     long totalRead = 0;
     long totalRead = 0;
     OutputStream streamForSendChunks = out;
     OutputStream streamForSendChunks = out;
     
     
+    lastCacheDropOffset = initialOffset;
+
+    if (isLongRead() && blockInFd != null) {
+      // Advise that this file descriptor will be accessed sequentially.
+      NativeIO.posixFadviseIfPossible(blockInFd, 0, 0,
+          NativeIO.POSIX_FADV_SEQUENTIAL);
+    }
+
+    // Trigger readahead of beginning of file if configured.
+    manageOsCache();
+
     final long startTime = ClientTraceLog.isInfoEnabled() ? System.nanoTime() : 0; 
     final long startTime = ClientTraceLog.isInfoEnabled() ? System.nanoTime() : 0; 
     try {
     try {
       try {
       try {
@@ -433,6 +486,7 @@ class BlockSender implements java.io.Closeable, FSConstants {
       ByteBuffer pktBuf = ByteBuffer.allocate(pktSize);
       ByteBuffer pktBuf = ByteBuffer.allocate(pktSize);
 
 
       while (endOffset > offset) {
       while (endOffset > offset) {
+        manageOsCache();
         long len = sendChunks(pktBuf, maxChunksPerPacket, 
         long len = sendChunks(pktBuf, maxChunksPerPacket, 
                               streamForSendChunks);
                               streamForSendChunks);
         offset += len;
         offset += len;
@@ -465,6 +519,39 @@ class BlockSender implements java.io.Closeable, FSConstants {
     return totalRead;
     return totalRead;
   }
   }
   
   
+  /**
+   * Manage the OS buffer cache by performing read-ahead and drop-behind.
+   */
+  private void manageOsCache() throws IOException {
+    if (!isLongRead() || blockInFd == null) {
+      // don't manage cache manually for short-reads, like
+      // HBase random read workloads.
+      return;
+    }
+
+    // Perform readahead if necessary
+    if (readaheadLength > 0 && readaheadPool != null) {
+      curReadahead = readaheadPool.readaheadStream(clientTraceFmt, blockInFd,
+          offset, readaheadLength, Long.MAX_VALUE, curReadahead);
+    }
+
+    // Drop what we've just read from cache, since we aren't
+    // likely to need it again
+    long nextCacheDropOffset = lastCacheDropOffset + CACHE_DROP_INTERVAL_BYTES;
+    if (shouldDropCacheBehindRead && offset >= nextCacheDropOffset) {
+      long dropLength = offset - lastCacheDropOffset;
+      if (dropLength >= 1024) {
+        NativeIO.posixFadviseIfPossible(blockInFd, lastCacheDropOffset,
+            dropLength, NativeIO.POSIX_FADV_DONTNEED);
+      }
+      lastCacheDropOffset += CACHE_DROP_INTERVAL_BYTES;
+    }
+  }
+
+  private boolean isLongRead() {
+    return (endOffset - offset) > LONG_READ_THRESHOLD_BYTES;
+  }
+
   boolean isBlockReadFully() {
   boolean isBlockReadFully() {
     return blockReadFully;
     return blockReadFully;
   }
   }

+ 34 - 0
src/hdfs/org/apache/hadoop/hdfs/server/datanode/DataNode.java

@@ -227,6 +227,11 @@ public class DataNode extends Configured
   int socketTimeout;
   int socketTimeout;
   int socketWriteTimeout = 0;  
   int socketWriteTimeout = 0;  
   boolean transferToAllowed = true;
   boolean transferToAllowed = true;
+  private boolean dropCacheBehindWrites = false;
+  private boolean syncBehindWrites = false;
+  private boolean dropCacheBehindReads = false;
+  private long readaheadLength = 0;
+
   int writePacketSize = 0;
   int writePacketSize = 0;
   private boolean durableSync;
   private boolean durableSync;
   boolean isBlockTokenEnabled;
   boolean isBlockTokenEnabled;
@@ -425,6 +430,19 @@ public class DataNode extends Configured
         new DataXceiverServer(ss, conf, this));
         new DataXceiverServer(ss, conf, this));
     this.threadGroup.setDaemon(true); // auto destroy when empty
     this.threadGroup.setDaemon(true); // auto destroy when empty
 
 
+    this.readaheadLength = conf.getLong(
+        DFSConfigKeys.DFS_DATANODE_READAHEAD_BYTES_KEY,
+        DFSConfigKeys.DFS_DATANODE_READAHEAD_BYTES_DEFAULT);
+    this.dropCacheBehindWrites = conf.getBoolean(
+        DFSConfigKeys.DFS_DATANODE_DROP_CACHE_BEHIND_WRITES_KEY,
+        DFSConfigKeys.DFS_DATANODE_DROP_CACHE_BEHIND_WRITES_DEFAULT);
+    this.syncBehindWrites = conf.getBoolean(
+        DFSConfigKeys.DFS_DATANODE_SYNC_BEHIND_WRITES_KEY,
+        DFSConfigKeys.DFS_DATANODE_SYNC_BEHIND_WRITES_DEFAULT);
+    this.dropCacheBehindReads = conf.getBoolean(
+        DFSConfigKeys.DFS_DATANODE_DROP_CACHE_BEHIND_READS_KEY,
+        DFSConfigKeys.DFS_DATANODE_DROP_CACHE_BEHIND_READS_DEFAULT);
+
     this.blockReportInterval =
     this.blockReportInterval =
       conf.getLong("dfs.blockreport.intervalMsec", BLOCKREPORT_INTERVAL);
       conf.getLong("dfs.blockreport.intervalMsec", BLOCKREPORT_INTERVAL);
     this.initialBlockReportDelay = conf.getLong("dfs.blockreport.initialDelay",
     this.initialBlockReportDelay = conf.getLong("dfs.blockreport.initialDelay",
@@ -2172,4 +2190,20 @@ public class DataNode extends Configured
                        (DataXceiverServer) this.dataXceiverServer.getRunnable();
                        (DataXceiverServer) this.dataXceiverServer.getRunnable();
     return dxcs.balanceThrottler.getBandwidth();
     return dxcs.balanceThrottler.getBandwidth();
   }
   }
+
+  long getReadaheadLength() {
+    return readaheadLength;
+  }
+
+  boolean shouldDropCacheBehindWrites() {
+    return dropCacheBehindWrites;
+  }
+
+  boolean shouldDropCacheBehindReads() {
+    return dropCacheBehindReads;
+  }
+
+  boolean shouldSyncBehindWrites() {
+    return syncBehindWrites;
+  }
 }
 }