public class ReplicaBeingWritten extends LocalReplicaInPipeline
LocalReplica.ReplicaDirInfo| Constructor and Description | 
|---|
| ReplicaBeingWritten(org.apache.hadoop.hdfs.protocol.Block block,
                   FsVolumeSpi vol,
                   File dir,
                   Thread writer)Constructor. | 
| ReplicaBeingWritten(long blockId,
                   long genStamp,
                   FsVolumeSpi vol,
                   File dir,
                   long bytesToReserve)Constructor for a zero length replica. | 
| ReplicaBeingWritten(long blockId,
                   long len,
                   long genStamp,
                   FsVolumeSpi vol,
                   File dir,
                   Thread writer,
                   long bytesToReserve)Constructor. | 
| ReplicaBeingWritten(ReplicaBeingWritten from)Copy constructor. | 
| Modifier and Type | Method and Description | 
|---|---|
| boolean | equals(Object o) | 
| HdfsServerConstants.ReplicaState | getState()Get the replica state | 
| long | getVisibleLength()Get the number of bytes that are visible to readers | 
| int | hashCode() | 
attemptToSetWriter, createInfo, createRestartMetaStream, createStreams, getBytesAcked, getBytesOnDisk, getBytesReserved, getLastChecksumAndDataLen, getOriginalBytesReserved, getOriginalReplica, getRecoveryID, getReplicaInfo, interruptThread, moveReplicaFrom, releaseAllBytesReserved, setBytesAcked, setLastChecksumAndDataLen, setRecoveryID, setWriter, stopWriter, toString, waitForMinLengthblockDataExists, breakHardLinksIfNeeded, bumpReplicaGS, compareWith, copyBlockdata, copyMetadata, deleteBlockData, deleteMetadata, fsyncDirectory, getBlockDataLength, getBlockFile, getBlockURI, getDataInputStream, getDataOutputStream, getDir, getMetadataInputStream, getMetadataLength, getMetadataOutputStream, getMetadataURI, getMetaFile, getPinning, getPinning, metadataExists, parseBaseDir, renameData, renameMeta, setPinning, setPinning, truncateBlock, truncateBlock, updateWithReplicagetFileIoProvider, getNext, getStorageUuid, getVolume, isOnTransientStorage, setNextappendStringTo, compareTo, filename2id, getBlockId, getBlockId, getBlockName, getGenerationStamp, getGenerationStamp, getNumBytes, isBlockFilename, isMetaFilename, matchingIdAndGenStamp, metaToBlockFile, readFields, readId, set, setBlockId, setGenerationStamp, setNumBytes, toString, write, writeIdclone, finalize, getClass, notify, notifyAll, wait, wait, waitsetNumBytespublic ReplicaBeingWritten(long blockId,
                           long genStamp,
                           FsVolumeSpi vol,
                           File dir,
                           long bytesToReserve)
blockId - block idgenStamp - replica generation stampvol - volume where replica is locateddir - directory path where block and meta files are locatedbytesToReserve - disk space to reserve for this replica, based on
                       the estimated maximum block length.public ReplicaBeingWritten(org.apache.hadoop.hdfs.protocol.Block block,
                           FsVolumeSpi vol,
                           File dir,
                           Thread writer)
block - a blockvol - volume where replica is locateddir - directory path where block and meta files are locatedwriter - a thread that is writing to this replicapublic ReplicaBeingWritten(long blockId,
                           long len,
                           long genStamp,
                           FsVolumeSpi vol,
                           File dir,
                           Thread writer,
                           long bytesToReserve)
blockId - block idlen - replica lengthgenStamp - replica generation stampvol - volume where replica is locateddir - directory path where block and meta files are locatedwriter - a thread that is writing to this replicabytesToReserve - disk space to reserve for this replica, based on
                       the estimated maximum block length.public ReplicaBeingWritten(ReplicaBeingWritten from)
from - where to copy frompublic long getVisibleLength()
org.apache.hadoop.hdfs.server.datanode.ReplicagetVisibleLength in interface org.apache.hadoop.hdfs.server.datanode.ReplicagetVisibleLength in class LocalReplicaInPipelinepublic HdfsServerConstants.ReplicaState getState()
org.apache.hadoop.hdfs.server.datanode.ReplicagetState in interface org.apache.hadoop.hdfs.server.datanode.ReplicagetState in class LocalReplicaInPipelinepublic boolean equals(Object o)
equals in class LocalReplicaInPipelinepublic int hashCode()
hashCode in class LocalReplicaInPipelineCopyright © 2008–2023 Apache Software Foundation. All rights reserved.