Package | Description |
---|---|
org.apache.hadoop.hdfs.server.datanode | |
org.apache.hadoop.hdfs.server.datanode.checker |
Datanode support for running disk checks.
|
org.apache.hadoop.hdfs.server.datanode.fsdataset |
Modifier and Type | Method and Description |
---|---|
FsVolumeSpi |
ReplicaHandler.getVolume() |
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(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.
|
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
|
ReplicaInPipeline(long blockId,
long genStamp,
FsVolumeSpi vol,
File dir,
long bytesToReserve)
Constructor for a zero length replica
|
ReplicaWaitingToBeRecovered(org.apache.hadoop.hdfs.protocol.Block block,
FsVolumeSpi vol,
File dir)
Constructor
|
ReplicaWaitingToBeRecovered(long blockId,
long len,
long genStamp,
FsVolumeSpi vol,
File dir)
Constructor
|
Modifier and Type | Method and Description |
---|---|
Set<FsVolumeSpi> |
DatasetVolumeChecker.checkAllVolumes(org.apache.hadoop.hdfs.server.datanode.fsdataset.FsDatasetSpi<? extends FsVolumeSpi> dataset)
Run checks against all volumes of a dataset.
|
Modifier and Type | Method and Description |
---|---|
boolean |
DatasetVolumeChecker.checkVolume(FsVolumeSpi volume,
DatasetVolumeChecker.Callback callback)
Check a single volume asynchronously, returning a
ListenableFuture
that can be used to retrieve the final result. |
Modifier and Type | Method and Description |
---|---|
void |
DatasetVolumeChecker.Callback.call(Set<FsVolumeSpi> healthyVolumes,
Set<FsVolumeSpi> failedVolumes) |
void |
DatasetVolumeChecker.Callback.call(Set<FsVolumeSpi> healthyVolumes,
Set<FsVolumeSpi> failedVolumes) |
Set<FsVolumeSpi> |
DatasetVolumeChecker.checkAllVolumes(org.apache.hadoop.hdfs.server.datanode.fsdataset.FsDatasetSpi<? extends FsVolumeSpi> dataset)
Run checks against all volumes of a dataset.
|
Modifier and Type | Class and Description |
---|---|
class |
AvailableSpaceVolumeChoosingPolicy<V extends FsVolumeSpi>
A DN volume choosing policy which takes into account the amount of free
space on each of the available volumes when considering where to assign a
new replica allocation.
|
class |
RoundRobinVolumeChoosingPolicy<V extends FsVolumeSpi>
Choose volumes with the same storage type in round-robin order.
|
Modifier and Type | Method and Description |
---|---|
FsVolumeSpi |
FsDatasetSpi.FsVolumeReferences.get(int index)
Get the volume for a given index.
|
FsVolumeSpi |
FsVolumeReference.getVolume()
Returns the underlying volume object.
|
Modifier and Type | Method and Description |
---|---|
Iterator<FsVolumeSpi> |
FsDatasetSpi.FsVolumeReferences.iterator() |
Constructor and Description |
---|
ReplicaOutputStreams(OutputStream dataOut,
OutputStream checksumOut,
org.apache.hadoop.util.DataChecksum checksum,
FsVolumeSpi volume,
org.apache.hadoop.hdfs.server.datanode.FileIoProvider fileIoProvider)
Create an object with a data output stream, a checksum output stream
and a checksum.
|
Copyright © 2020 Apache Software Foundation. All rights reserved.