public class FinalizedReplica extends LocalReplica
LocalReplica.ReplicaDirInfo
Constructor and Description |
---|
FinalizedReplica(org.apache.hadoop.hdfs.protocol.Block block,
FsVolumeSpi vol,
File dir)
Constructor
|
FinalizedReplica(org.apache.hadoop.hdfs.protocol.Block block,
FsVolumeSpi vol,
File dir,
byte[] checksum)
Constructor
|
FinalizedReplica(FinalizedReplica from)
Copy constructor.
|
FinalizedReplica(long blockId,
long len,
long genStamp,
FsVolumeSpi vol,
File dir)
Constructor.
|
FinalizedReplica(long blockId,
long len,
long genStamp,
FsVolumeSpi vol,
File dir,
byte[] checksum)
Constructor.
|
Modifier and Type | Method and Description |
---|---|
org.apache.hadoop.hdfs.server.protocol.ReplicaRecoveryInfo |
createInfo() |
boolean |
equals(Object o) |
long |
getBytesOnDisk()
Get the number of bytes that have written to disk
|
byte[] |
getLastPartialChunkChecksum() |
org.apache.hadoop.hdfs.server.datanode.ReplicaInfo |
getOriginalReplica() |
long |
getRecoveryID()
Get the recovery id.
|
HdfsServerConstants.ReplicaState |
getState()
Get the replica state
|
long |
getVisibleLength()
Get the number of bytes that are visible to readers
|
int |
hashCode() |
void |
loadLastPartialChunkChecksum() |
void |
setLastPartialChunkChecksum(byte[] checksum) |
void |
setRecoveryID(long recoveryId)
Set the recovery id.
|
String |
toString() |
blockDataExists, 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, updateWithReplica
getBytesReserved, getFileIoProvider, getNext, getOriginalBytesReserved, getStorageUuid, getVolume, isOnTransientStorage, setNext
appendStringTo, compareTo, filename2id, getBlockId, getBlockId, getBlockName, getGenerationStamp, getGenerationStamp, getNumBytes, isBlockFilename, isMetaFilename, matchingIdAndGenStamp, metaToBlockFile, readFields, readId, set, setBlockId, setGenerationStamp, setNumBytes, toString, write, writeId
public FinalizedReplica(long blockId, long len, long genStamp, FsVolumeSpi vol, File dir)
blockId
- block idlen
- replica lengthgenStamp
- replica generation stampvol
- volume where replica is locateddir
- directory path where block and meta files are locatedpublic FinalizedReplica(long blockId, long len, long genStamp, FsVolumeSpi vol, File dir, byte[] checksum)
blockId
- block idlen
- replica lengthgenStamp
- replica generation stampvol
- volume where replica is locateddir
- directory path where block and meta files are locatedchecksum
- the last partial chunk checksumpublic FinalizedReplica(org.apache.hadoop.hdfs.protocol.Block block, FsVolumeSpi vol, File dir)
block
- a blockvol
- volume where replica is locateddir
- directory path where block and meta files are locatedpublic FinalizedReplica(org.apache.hadoop.hdfs.protocol.Block block, FsVolumeSpi vol, File dir, byte[] checksum)
block
- a blockvol
- volume where replica is locateddir
- directory path where block and meta files are locatedchecksum
- the last partial chunk checksumpublic FinalizedReplica(FinalizedReplica from)
from
- where to copy construct frompublic HdfsServerConstants.ReplicaState getState()
org.apache.hadoop.hdfs.server.datanode.Replica
public long getVisibleLength()
org.apache.hadoop.hdfs.server.datanode.Replica
public long getBytesOnDisk()
org.apache.hadoop.hdfs.server.datanode.Replica
public boolean equals(Object o)
equals
in class org.apache.hadoop.hdfs.protocol.Block
public int hashCode()
hashCode
in class org.apache.hadoop.hdfs.protocol.Block
public String toString()
toString
in class org.apache.hadoop.hdfs.server.datanode.ReplicaInfo
public org.apache.hadoop.hdfs.server.datanode.ReplicaInfo getOriginalReplica()
getOriginalReplica
in class org.apache.hadoop.hdfs.server.datanode.ReplicaInfo
public long getRecoveryID()
org.apache.hadoop.hdfs.server.datanode.ReplicaInfo
getRecoveryID
in class org.apache.hadoop.hdfs.server.datanode.ReplicaInfo
public void setRecoveryID(long recoveryId)
org.apache.hadoop.hdfs.server.datanode.ReplicaInfo
setRecoveryID
in class org.apache.hadoop.hdfs.server.datanode.ReplicaInfo
recoveryId
- the new recoveryIdpublic org.apache.hadoop.hdfs.server.protocol.ReplicaRecoveryInfo createInfo()
createInfo
in class org.apache.hadoop.hdfs.server.datanode.ReplicaInfo
public byte[] getLastPartialChunkChecksum()
public void setLastPartialChunkChecksum(byte[] checksum)
public void loadLastPartialChunkChecksum() throws IOException
IOException
Copyright © 2008–2018 Apache Software Foundation. All rights reserved.