Hadoop源码分析之读文件时NameNode和DataNode的处理过程
转自: http://blog.csdn.net/workformywork/article/details/21783861
从NameNode节点获取数据块所在节点等信息
客户端在和数据节点建立流式接口的TCP连接,读取文件数据前需要定位数据的位置,所以首先客户端在 DFSClient.callGetBlockLocations()
方法中调用了远程方法 ClientProtocol.getBlockLocations()
,调用该方法返回一个LocatedBlocks对象,包含了一系列的LocatedBlock实例,通过这些信息客户端就知道需要到哪些数据节点上去获取数据。这个方法会在NameNode.getBlockLocations()中调用,进而调用FSNamesystem.同名的来进行实际的调用过程,FSNamesystem有三个重载方法,代码如下:
LocatedBlocks getBlockLocations(String clientMachine, String src,
long offset, long length) throws IOException {
LocatedBlocks blocks = getBlockLocations(src, offset, length, true, true,
true);
if (blocks != null) {//如果blocks不为空,那么就对数据块所在的数据节点进行排序
//sort the blocks
// In some deployment cases, cluster is with separation of task tracker
// and datanode which means client machines will not always be recognized
// as known data nodes, so here we should try to get node (but not
// datanode only) for locality based sort.
Node client = host2DataNodeMap.getDatanodeByHost(
clientMachine);
if (client == null) {
List<String> hosts = new ArrayList<String> (1);
hosts.add(clientMachine);
String rName = dnsToSwitchMapping.resolve(hosts).get(0);
if (rName != null)
client = new NodeBase(clientMachine, rName);
}
DFSUtil.StaleComparator comparator = null;
if (avoidStaleDataNodesForRead) {
comparator = new DFSUtil.StaleComparator(staleInterval);
}
// Note: the last block is also included and sorted
for (LocatedBlock b : blocks.getLocatedBlocks()) {
clusterMap.pseudoSortByDistance(client, b.getLocations());
if (avoidStaleDataNodesForRead) {
Arrays.sort(b.getLocations(), comparator);
}
}
}
return blocks;
}
/**
* Get block locations within the specified range.
* @see ClientProtocol#getBlockLocations(String, long, long)
*/
public LocatedBlocks getBlockLocations(String src, long offset, long length
) throws IOException {
return getBlockLocations(src, offset, length, false, true, true);
}
/**
* Get block locations within the specified range.
* @see ClientProtocol#getBlockLocations(String, long, long)
*/
public LocatedBlocks getBlockLocations(String src, long offset, long length,
boolean doAccessTime, boolean needBlockToken, boolean checkSafeMode)
throws IOException {
if (isPermissionEnabled) {//读权限检查
FSPermissionChecker pc = getPermissionChecker();
checkPathAccess(pc, src, FsAction.READ);
}
if (offset < 0) {
throw new IOException("Negative offset is not supported. File: " + src );
}
if (length < 0) {
throw new IOException("Negative length is not supported. File: " + src );
}
final LocatedBlocks ret = getBlockLocationsInternal(src,
offset, length, Integer.MAX_VALUE, doAccessTime, needBlockToken);
if (auditLog.isInfoEnabled() && isExternalInvocation()) {
logAuditEvent(UserGroupInformation.getCurrentUser(),
Server.getRemoteIp(),
"open", src,null,null);}if(checkSafeMode && isInSafeMode()){for(LocatedBlock b : ret.getLocatedBlocks()){// if safemode & no block locations yet then throw safemodeExceptionif((b.getLocations()==null)||(b.getLocations().length ==0)){thrownewSafeModeException("Zero blocklocations for "+ src,
safeMode);}}}return ret;}
从上面的代码可以看出,前两个方法都是调用了第三个重载方法,第二个方法获取到数据块之后,还会根据客户端和获取到的节点列表进行”排序”,“排序”调用的方法是:
public void pseudoSortByDistance( Node reader, Node[] nodes ) {
int tempIndex = 0;
if (reader != null ) {
int localRackNode = -1;
//scan the array to find the local node & local rack node
for(int i=0; i<nodes.length; i++) {//遍历nodes,看reader是否在nodes中
if(tempIndex == 0 && reader == nodes[i]) { //local node
//swap the local node and the node at position 0
//第i个数据节点与客户端是一台机器
if( i != 0 ) {
swap(nodes, tempIndex, i);
}
tempIndex=1;
if(localRackNode != -1 ) {
if(localRackNode == 0) {//localRackNode==0表示在没有交换之前,第0个节点是
//与reader位于同一机架上的节点,现在交换了,那么第i个就是与reader在同一机架上的节点
localRackNode = i;
}
break;//第0个是reader节点,第i个是与reader在同一机架上的节点,那么剩下的节点就一定在这个机架上,跳出循环
}
} else if(localRackNode == -1 && isOnSameRack(reader, nodes[i])) {
//local rack,节点i和Reader在同一个机架上
localRackNode = i;
if(tempIndex != 0 ) break;//tempIndex != 0表示reader在nodes中
}
}
//如果reader在nodes中,那么tempIndex==1,否则tempIndex = 0,如果localRackNode != 1,那么localRackNode节点就
//是与reader位于同一机架上的节点,交换localRackNode到tempIndex,这样如果reader在nodes中,localRackNode与reader
//在同一个机架上,那么第0个就是reader节点,第1个就是localRackNode节点,如果reader不在nodes中,
//localRackNode与reader在同一个机架上,那么第0个就是localRackNode节点,否则就随机找一个
if(localRackNode != -1 && localRackNode != tempIndex ) {
swap(nodes, tempIndex, localRackNode);
tempIndex++;
}
}
//tempIndex == 0,则在nodes中既没有reader,也没有与reader在同一机架上的节点
if(tempIndex == 0 && nodes.length != 0) {
swap(nodes, 0, r.nextInt(nodes.length));
}
}
“排序”的规则是如果reader节点在nodes节点列表中,那么将reader放在nodes的第0个位置,如果在nodes中有与reader在同一机架上的节点localRackNode,那么就将localRackNode节点放在reader后面(如果reader不在nodes中,可以将reader视作在nodes的第-1个位置),如果也不存在与reader在同一机架上的节点,那么就在nodes中随机选择一个节点放在第0个位置。
在FSNamesystem.getBlockLocations()的第三个重载方法中,调用了FSNamesystem.getBlockLocationsInternal()方法来具体处理充NameNode节点的目录树中到文件所对应的数据块,这个方法代码如下:
private synchronized LocatedBlocks getBlockLocationsInternal(String src,
long offset,
long length,
int nrBlocksToReturn,
boolean doAccessTime,
boolean needBlockToken)
throws IOException {
//获取src路径上最后一个节点即文件节点
INodeFile inode = dir.getFileINode(src);
if(inode == null) {
return null;
}
if (doAccessTime && isAccessTimeSupported()) {
//修改最后访问时间
dir.setTimes(src, inode, -1, now(), false);
}
//返回文件的数据块
Block[] blocks = inode.getBlocks();
if (blocks == null) {
return null;
}
if (blocks.length == 0) {//节点为空
return inode.createLocatedBlocks(new ArrayList<LocatedBlock>(blocks.length));
}
//下面开始遍历所有该文件的所有数据块,直到到达offset所在的数据块
List<LocatedBlock> results;
results = new ArrayList<LocatedBlock>(blocks.length);
int curBlk = 0;
long curPos = 0, blkSize = 0;
//数据块的个数
int nrBlocks = (blocks[0].getNumBytes() == 0) ? 0 : blocks.length;
for (curBlk = 0; curBlk < nrBlocks; curBlk++) {
blkSize = blocks[curBlk].getNumBytes();
assert blkSize > 0 : "Block of size 0";
if (curPos + blkSize > offset) {//如果curPos + blkSize > offset则遍历到了offset所在的数据块
break;
}
curPos += blkSize;
}
//curBlk == nrBlocks说明offset超过了文件的长度
if (nrBlocks > 0 && curBlk == nrBlocks) // offset >= end of file
return null;
//找到了offset所在的数据块
long endOff = offset + length;
//下面对于每一个curBlk和其后的每个数据块,先获取其副本,然后检查该副本是否已经损坏,如果是部分损坏,则过滤掉其余的损坏的副本
//将正常的副本加入到machineSet中,返回,如果所有的副本都损坏,则将所有的副本都加入这个数据块对应的machineSet中,再对
//machineSet构造LocatedBlock对象
do {
// get block locations,获取数据块所在的数据节点
int numNodes = blocksMap.numNodes(blocks[curBlk]);//有numNodes个数据节点保存这个数据块
int numCorruptNodes = countNodes(blocks[curBlk]).corruptReplicas();//损坏的副本数量
int numCorruptReplicas = corruptReplicas.numCorruptReplicas(blocks[curBlk]);
if (numCorruptNodes != numCorruptReplicas) {
LOG.warn("Inconsistent number of corrupt replicas for " +
blocks[curBlk] + "blockMap has " + numCorruptNodes +
" but corrupt replicas map has " + numCorruptReplicas);
}
DatanodeDescriptor[] machineSet = null;
boolean blockCorrupt = false;
if (inode.isUnderConstruction() && curBlk == blocks.length - 1&& blocksMap.numNodes(blocks[curBlk])==0){//最后一个副本处于构建状态,不用检查是否有损坏的副本// get unfinished block locationsINodeFileUnderConstruction cons =(INodeFileUnderConstruction)inode;
machineSet = cons.getTargets();
blockCorrupt =false;}else{
blockCorrupt =(numCorruptNodes == numNodes);//数据块的所有副本是否都已经损坏int numMachineSet = blockCorrupt ? numNodes :(numNodes - numCorruptNodes);//未损坏的副本数量
machineSet =newDatanodeDescriptor[numMachineSet];if(numMachineSet >0){
numNodes =0;for(Iterator<DatanodeDescriptor> it =
blocksMap.nodeIterator(blocks[curBlk]); it.hasNext();){//遍历所有副本DatanodeDescriptor dn = it.next();boolean replicaCorrupt = corruptReplicas.isReplicaCorrupt(blocks[curBlk], dn);if(blockCorrupt ||(!blockCorrupt &&!replicaCorrupt))//数据块已经损坏或者部分副本损坏
machineSet[numNodes++]= dn;}}}LocatedBlock b =newLocatedBlock(blocks[curBlk], machineSet, curPos,
blockCorrupt);if(isAccessTokenEnabled && needBlockToken){
b.setBlockToken(accessTokenHandler.generateToken(b.getBlock(),EnumSet.of(BlockTokenSecretManager.AccessMode.READ)));}
results.add(b);
curPos += blocks[curBlk].getNumBytes();
curBlk++;}while(curPos < endOff
&& curBlk < blocks.length
&& results.size()< nrBlocksToReturn);return inode.createLocatedBlocks(results);}
这个方法比较长,首先是执行 INodeFile inode = dir.getFileINode(src);
这行代码获取src路径上的文件节点,FSDirectory.getFileINode()方法根据文件路径,查找找到路径分隔符的最后一个元素,如果这个元素代表的文件存在,则返回该文件的对象,如果不存在,就为返回null。需要说明的是在HDFS的目录树中,根目录是一个空字符串即””,使用rootDir表示那么路径rootDir/home/hadoop这个路径的真实值为”/home/hadoop”。
并且在INode类中,文件/目录名遍历name是一个字节数组,如果name.length为0,则是根节点。 FSDirectory.getFileINode(String src)
方法会通过rootDir.getNode(src);获取src的的文件节点对象即src文件所对应的INode对象,这个过程中会调用INode.getPathComponents(String path)方法会返回路径path上每个以/分隔的字符串的字节数组,即得到路径中的每个目录和文件名的字节数组,为什么要获取到路径目录和文件的字节数组?因为INode.name是二进制格式,INodeDirectory.getExistingPathINodes()方法会使用二分查找,看目录或文件是否存在,具体代码比较简单。
如果通过 FSDirectory.getFileINode(String src)
返回的INode对象为null,那么直接返回null值,否则,根据参数 doAccessTime
来确定是否有修改文件的最后访问时间。
继续向下执行getBlockLocationsInternal方法,接下来根据以上获取到的INode对象获取到这个文件对应的数据块信息,如果数据块为null,则返回null,如果数据块数组长度为0,那么创建一个LocatedBlocks对象,这个对象中对应的数据块数组元素个数为0,稍后会继续分析如何根据数据块数组来创建LocatedBlocks对象。
如果该文件对应的数据块数组元素个数大于0,那么就遍历所有该文件的所有数据块,直到到达参数offset所在的数据块,其中offset是文件中数据的偏移,它一定在某个数据块中。具体的方法是:设置一个指针curPos表示当前的偏移,每次访问一个数据块,就看curPos与数据块的大小的和是否大于offset,如果小于就让curPos的值加上数据块的大小,如果大于就停止遍历,这样就找到了offset所在的数据块。
接下来就根据剩余的数据块副本来构造DataNode数据节点列表,对于每个数据块,检查其损坏副本的数量,首先对同一个数据块检查blockMap中的损坏副本与corruptReplicas中记录的损坏副本是否相同,如果不同就记录log信息。numCorruptNodes和numCorruptReplicas虽然都代表损坏副本的额数量,但是求这两个值的方式不同,numCorruptNodes是先根据数据块从blocksMap中取出这个数据块对应的DataNode节点,再看这个这个数据块对应的DataNode节点是否在corruptReplicas(这个遍历保存了已经损坏的数据块副本)中,numCorruptNodes表示这个数据块对应的DataNode节点有多少在corruptReplicas中,而numCorruptReplicas则是根据数据块来检查在corruptReplicas中有多少对应的节点,有可能这两个值不一致。
对于每一个数据块,找到这个数据块所有的正常副本,然后构造一个LocatedBlock对象,这个对象保存了对应的数据块的所有正常副本所在的DataNode节点,以及这个数据块在文件中的偏移等信息。如果一个数据块的所有副本都损坏,则将这个数据块的所有副本都返回给客户端,但是LocatedBlock中的 corrupt
属性记录为true,它表示这个数据块的所有副本都损坏了。此外如果当前数据块是文件的最后一个数据块,并且这个数据块还于构建状态,不用检查是否有损坏的副本,直接将它的所有副本返回给客户端。
执行以上的过程就完成了数据块从NameNode获取文件副本的过程。
从数据节点获取数据块内容
客户端获取到数据块以及其所在的DataNode节点信息后,就可以联系DataNode节点来读文件数据了。HDFS提供了DataXceiverServer类和DataXceiver类来处理客户端的读请求,其中DataXceiverServer类用于接收客户端的Socket连接请求,然后创建一个DataXceiver线程来接收客户端的读数据请求,这个DataXceiver线程接受到客户端的读数据请求后,就可以将数据发送给客户端了。这个过程是一个基本Java的Socket通信,与Java提供的NIO不同,这种通信方式每个客户端读请求在DataNode中都对应一个单独的线程。
客户端读数据是基于TCP数据流,使用了Java的基本套接字的功能。在HDFS启动DataNode时,执行DataNode.startDataNode()方法过程中创建了一个java.net.ServerSocket对象,然后构造一个DataXceiverServer线程专门用于accept客户端。DataXceiverServer线程启动后就阻塞在accpt方法中,等待着客户端的连接请求,只要有客户端连接过来,就会完成accept方法,然后创建一个DataXceiver线程用于处理客户端的读数据请求,accept客户端的这部分代码实现在DataXceiverServer.run()方法中,代码比较简单。
客户端的连接被接收后DataNode节点就建立了一个DataXceiver线程,在DataXceiver线程的run方法中处理客户端的读数据请求,方法代码如下:
public void run() {
DataInputStream in=null;
try {
//创建输入流
in = new DataInputStream(
new BufferedInputStream(NetUtils.getInputStream(s),
SMALL_BUFFER_SIZE));
//进行版本检查
short version = in.readShort();
if ( version != DataTransferProtocol.DATA_TRANSFER_VERSION ) {
throw new IOException( "Version Mismatch" );
}
boolean local = s.getInetAddress().equals(s.getLocalAddress());//socket连接的远程地址是否是本地机器的地址,即是否连接到了本地机器
byte op = in.readByte();//读入请求码
// Make sure the xciver count is not exceeded,DataNode中读写请求的数量,即DataXceiver线程的数量有个阈值
int curXceiverCount = datanode.getXceiverCount();
if (curXceiverCount > dataXceiverServer.maxXceiverCount) {//该请求是否超出数据节点的支撑能力,以确保数据节点的服务质量
throw new IOException("xceiverCount " + curXceiverCount
+ " exceeds the limit of concurrent xcievers "
+ dataXceiverServer.maxXceiverCount);
}
long startTime = DataNode.now();
switch ( op ) {
case DataTransferProtocol.OP_READ_BLOCK://客户端读数据
readBlock( in );
datanode.myMetrics.addReadBlockOp(DataNode.now() - startTime);
if (local)
datanode.myMetrics.incrReadsFromLocalClient();
else
datanode.myMetrics.incrReadsFromRemoteClient();
break;
case DataTransferProtocol.OP_WRITE_BLOCK://客户端写数据
writeBlock( in );
datanode.myMetrics.addWriteBlockOp(DataNode.now() - startTime);
if (local)
datanode.myMetrics.incrWritesFromLocalClient();
else
datanode.myMetrics.incrWritesFromRemoteClient();
break;
case DataTransferProtocol.OP_REPLACE_BLOCK: // for balancing purpose; send to a destination,数据块替换
replaceBlock(in);
datanode.myMetrics.addReplaceBlockOp(DataNode.now() - startTime);
break;
case DataTransferProtocol.OP_COPY_BLOCK://数据块拷贝
// for balancing purpose; send to a proxy source
copyBlock(in);
datanode.myMetrics.addCopyBlockOp(DataNode.now() - startTime);
break;
case DataTransferProtocol.OP_BLOCK_CHECKSUM: //get the checksum of a block,读数据块的校验信息
getBlockChecksum(in);
datanode.myMetrics.addBlockChecksumOp(DataNode.now() - startTime);
break;
default:
throw new IOException("Unknown opcode " + op + " in data stream");
}
} catch (Throwable t) {
LOG.error(datanode.dnRegistration + ":DataXceiver",t);
} finally {
LOG.debug(datanode.dnRegistration + ":Number of active connections is: "
+ datanode.getXceiverCount());
IOUtils.closeStream(in);
IOUtils.closeSocket(s);
dataXceiverServer.childSockets.remove(s);
}
}
DataXceiver线程除了用于处理客户端的读数据请求,还处理客户端写数据请求,DataNode节点之间的数据块替换,数据块拷贝和读数据块校验信息等功能,暂时只分析客户端读数据请求的部分,在上面的DataXceiver.run()方法中,首先根据参数创建一个输入流,用于读取客户端发送过来的请求数据,然后读取一个short类型的版本信息,检查客户端的数据传输接口值是否和DataNode节点一致,再读取请求操作码op,DataXceiver线程会根据客端的操作请求码op来进行不同的操作(switch语句),DataTransferProtocol.OP_READ_BLOCK
操作码代表读操作,如果是这个操作码,就执行DataXceiver.readBlock()方法,这个方法代码如下:
private void readBlock(DataInputStream in) throws IOException {
long blockId = in.readLong(); //要读取的数据块标识,数据节点通过它定位数据块
Block block = new Block( blockId, 0 , in.readLong());//这个in.readLong()方法读取数据版本号
long startOffset = in.readLong();//要读取数据位于数据块中的位置
long length = in.readLong();//客户端要读取的数据长度
String clientName = Text.readString(in);//发起读请求的客户端名字
Token<BlockTokenIdentifier> accessToken = new Token<BlockTokenIdentifier>();
accessToken.readFields(in);//安全相关
OutputStream baseStream = NetUtils.getOutputStream(s,
datanode.socketWriteTimeout);//Socket对应的输出流
DataOutputStream out = new DataOutputStream(
new BufferedOutputStream(baseStream, SMALL_BUFFER_SIZE));
if (datanode.isBlockTokenEnabled) {
try {
datanode.blockTokenSecretManager.checkAccess(accessToken, null, block,
BlockTokenSecretManager.AccessMode.READ);
} catch (InvalidToken e) {
try {
out.writeShort(DataTransferProtocol.OP_STATUS_ERROR_ACCESS_TOKEN);
out.flush();
throw new IOException("Access token verification failed, for client "
+ remoteAddress + " for OP_READ_BLOCK for " + block);
} finally {
IOUtils.closeStream(out);
}
}
}
// send the block
BlockSender blockSender = null;
final String clientTraceFmt =
clientName.length() > 0 && ClientTraceLog.isInfoEnabled()
? String.format(DN_CLIENTTRACE_FORMAT, localAddress, remoteAddress,
"%d", "HDFS_READ", clientName, "%d",
datanode.dnRegistration.getStorageID(), block, "%d")
: datanode.dnRegistration + " Served " + block + " to " +
s.getInetAddress();
try {
try {
blockSender = new BlockSender(block, startOffset, length,
true, true, false, datanode, clientTraceFmt);
} catch(IOException e) {//BlockSender的构造方法会进行一系列的检查,这些检查通过后,才会成功创建对象,否则通过异常返回给客户端
out.writeShort(DataTransferProtocol.OP_STATUS_ERROR);
throw e;
}
out.writeShort(DataTransferProtocol.OP_STATUS_SUCCESS); // send op status,操作成功状态
long read = blockSender.sendBlock(out, baseStream, null); // send data,发送数据
if (blockSender.isBlockReadFully()) {//客户端是否校验成功,这是一个客户端可选的响应
// See if client verification succeeded.
// This is an optional response from client.
try {
if (in.readShort() == DataTransferProtocol.OP_STATUS_CHECKSUM_OK &&
datanode.blockScanner != null){//客户端已经进行了数据块的校验,数据节点就可以省略重复的工作,减轻系统负载
datanode.blockScanner.verifiedByClient(block);}}catch(IOException ignored){}}
datanode.myMetrics.incrBytesRead((int) read);
datanode.myMetrics.incrBlocksRead();}catch(SocketException ignored ){// Its ok for remote side to close the connection anytime.
datanode.myMetrics.incrBlocksRead();}catch(IOException ioe ){/* What exactly should we do here?
* Earlier version shutdown() datanode if there is disk error.
*/
LOG.warn(datanode.dnRegistration +":Got exception while serving "+
block +" to "+ s.getInetAddress()+":\n"+StringUtils.stringifyException(ioe));throw ioe;}finally{IOUtils.closeStream(out);IOUtils.closeStream(blockSender);}}
这个方法先读取数据块标识和数据版本号,创建一个数据块对象(Block对象),然后依次读取数据位于数据块中的位置(startOffset),要读取的数据长度(length),发起读请求的客户端名字(clientName),安全标识(accessToken),再创建到客户端的输出流。
接下来就构造一个BlockSender对象用于向客户端发送数据,响应客户端的读数据请求,BlockSender的构造方法会进行一系列的检查,这些检查通过后,才会成功创建对象,否则通过异常返回给客户端。如果调用BlockSender构造方法没有抛出异常,则BlockSender对象创建成功,那么就向客户端写出一个DataTransferProtocol.OP_STATUS_SUCCESS
标识,接着调用BlockSender.sendBlock()方法发送数据。
如果客户端接收数据后校验成功,客户端会向DataNode节点发送一个DataTransferProtocol.OP_STATUS_CHECKSUM_OK
标识,DataNode节点可以通过这个标识通知数据块扫描器,让扫描器标识该数据块扫描成功,也可以看作客户端替这个DataNode节点的数据块扫描器检查了这个数据块,那么数据块扫描器就不用重复检查了,这样设计,数据节点就可以省略重复的工作,减轻系统负载。
上面分析到了构造BlockSender对象时会进行一系列检查,那么这些检查是怎么进行的呢?下面就来看看BlockSender对象的处理过程,其构造方法如下:
BlockSender(Block block, long startOffset, long length,
boolean corruptChecksumOk, boolean chunkOffsetOK,
boolean verifyChecksum, DataNode datanode, String clientTraceFmt)
throws IOException {
try {
this.block = block;//要发送的数据块
this.chunkOffsetOK = chunkOffsetOK;
this.corruptChecksumOk = corruptChecksumOk;
this.verifyChecksum = verifyChecksum;
this.blockLength = datanode.data.getVisibleLength(block);
this.transferToAllowed = datanode.transferToAllowed;
this.clientTraceFmt = clientTraceFmt;
this.readaheadLength = datanode.getReadaheadLength();
this.readaheadPool = datanode.readaheadPool;
this.shouldDropCacheBehindRead = datanode.shouldDropCacheBehindReads();
if ( !corruptChecksumOk || datanode.data.metaFileExists(block) ) {
checksumIn = new DataInputStream(
new BufferedInputStream(datanode.data.getMetaDataInputStream(block),
BUFFER_SIZE));
// read and handle the common header here. For now just a version
BlockMetadataHeader header = BlockMetadataHeader.readHeader(checksumIn);
short version = header.getVersion();
if (version != FSDataset.METADATA_VERSION) {
LOG.warn("Wrong version (" + version + ") for metadata file for "
+ block + " ignoring ...");
}
checksum = header.getChecksum();
} else {
LOG.warn("Could not find metadata file for " + block);
// This only decides the buffer size. Use BUFFER_SIZE?
checksum = DataChecksum.newDataChecksum(DataChecksum.CHECKSUM_NULL,
16 * 1024);
}
/* If bytesPerChecksum is very large, then the metadata file
* is mostly corrupted. For now just truncate bytesPerchecksum to
* blockLength.
*/
bytesPerChecksum = checksum.getBytesPerChecksum();
if (bytesPerChecksum > 10*1024*1024 && bytesPerChecksum > blockLength){
checksum = DataChecksum.newDataChecksum(checksum.getChecksumType(),
Math.max((int)blockLength, 10*1024*1024));
bytesPerChecksum = checksum.getBytesPerChecksum();
}
checksumSize = checksum.getChecksumSize();
if (length < 0) {
length = blockLength;
}
endOffset = blockLength;
if (startOffset < 0 || startOffset > endOffset
|| (length + startOffset) > endOffset) {
String msg = " Offset " + startOffset + " and length " + length
+ " don't match " + block + " ( blockLen " + endOffset + " )";
LOG.warn(datanode.dnRegistration + ":sendBlock() : " + msg);
throw new IOException(msg);
}
//应答数据在数据块中的开始位置
offset = (startOffset - (startOffset % bytesPerChecksum));
if (length >=0){// Make sure endOffset points to end of a checksumed chunk.long tmpLen = startOffset + length;if(tmpLen % bytesPerChecksum !=0){//用户读取数据的结束位置
tmpLen +=(bytesPerChecksum - tmpLen % bytesPerChecksum);}if(tmpLen < endOffset){
endOffset = tmpLen;}}// seek to the right offsets,设置读校验信息文件的位置信息if(offset >0){long checksumSkip =(offset / bytesPerChecksum)* checksumSize;// note blockInStream is seeked when created belowif(checksumSkip >0){// Should we use seek() for checksum file as well?,跳过不需要的部分IOUtils.skipFully(checksumIn, checksumSkip);}}
seqno =0;//打开数据块的文件输入流
blockIn = datanode.data.getBlockInputStream(block, offset);// seek to offsetif(blockIn instanceofFileInputStream){
blockInFd =((FileInputStream) blockIn).getFD();}else{
blockInFd =null;}
memoizedBlock =newMemoizedBlock(blockIn, blockLength, datanode.data, block);}catch(IOException ioe){IOUtils.closeStream(this);IOUtils.closeStream(blockIn);throw ioe;}}
在这个方法中,首先根据构造函数的参数为BlockSender的部分成员变量赋值,其中block为要发送的数据块对象,startOffset为要读取数据位于数据块中的位置,length为要读取的数据长度,corruptChecksumOk为true那么就表示不需要发送这个数据块文件对应的校验文件的数据,否则就必须要发送数据块文件的校验文件信息。
如果corruptChecksumOk为false,且数据块文件对应的校验文件存在,那么就创建这个校验文件输入流checksumIn,然后读入这个文件的头部信息,即文件中校验数据之前的数据,并且读入的元数据版本号与 FSDataset.METADATA_VERSION
比较。
方法中客户端要读取的偏移起点用startOffset标识,结束点用endOffset表示,由于校验块大小是一定的(默认为512字节),若startOffset在一个校验块内,那么这样传输客户端就会校验出错,即如果DataNode节点从startOffset处开始发送,那么客户端收到的数据校验后就与校验数据不一致(校验数据无法拆分),所以就必须从startOffset所在的那个校验块的起点开始发送数据,同理,endOffset如果在一个校验块内,那么就要截至到这个校验的结束,如下图所示
图中有三个校验块,阴影部分为要读取的数据部分,所以这部分的起始和结尾出刚好落在了第一个数据块和第3个数据块中。
根据上面的分析,DataNode节点发送的数据起点是计算得到的offset值,结束点是计算得到的endOffset值,然后就创建数据块文件的输入数据流blockIn,这样就成功创建了BlockSender对象。
创建完BlockSender对象,就可以通过这个对象向客户端发送数据了,具体过程实现在BlockSender.sendBlock()
方法中,代码如下:
long sendBlock(DataOutputStream out, OutputStream baseStream,
DataTransferThrottler throttler) throws IOException {
if( out == null ) {
throw new IOException( "out stream is null" );
}
this.throttler = throttler;
initialOffset = offset;
long totalRead = 0;
OutputStream streamForSendChunks = out;
lastCacheDropOffset = initialOffset;
// Advise that this file descriptor will be accessed sequentially.
//调用Linux的posix_fadvise函数来声明blockInfd的访问方式
if (isLongRead() && blockInFd != null) {//如果要读取的数据长度超过一定值,并且文件描述符不为空,那么就设置对文件的访问方式
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;
//发送应答头部信息,包含数据校验类型,校验块大小,偏移量,其中对于客户端请求,偏移量是必选参数
try {
try {
checksum.writeHeader(out);//发送数据校验类型,校验块大小
if ( chunkOffsetOK ) {
out.writeLong( offset );//发送偏移量
}
out.flush();
} catch (IOException e) { //socket error
throw ioeToSocketException(e);
}
//根据缓冲区大小配置,计算一次能够发送多少校验块的数据,并分配工作缓冲区
int maxChunksPerPacket;
int pktSize = DataNode.PKT_HEADER_LEN + SIZE_OF_INTEGER;
if (transferToAllowed && !verifyChecksum &&
baseStream instanceof SocketOutputStream &&
blockIn instanceof FileInputStream) {//零拷贝传输方式
FileChannel fileChannel = ((FileInputStream)blockIn).getChannel();
// blockInPosition also indicates sendChunks() uses transferTo.
blockInPosition = fileChannel.position();
streamForSendChunks = baseStream;
// assure a mininum buffer size.
maxChunksPerPacket = (Math.max(BUFFER_SIZE,
MIN_BUFFER_WITH_TRANSFERTO)
+ bytesPerChecksum - 1)/bytesPerChecksum;//一次发送几个校验块
// packet buffer has to be able to do a normal transfer in the case
// of recomputing checksum,缓冲区需要能够执行一次普通传输
pktSize += (bytesPerChecksum + checksumSize) * maxChunksPerPacket;
} else {//传统的传输方式
maxChunksPerPacket = Math.max(1,
(BUFFER_SIZE + bytesPerChecksum - 1)/bytesPerChecksum);
pktSize += (bytesPerChecksum + checksumSize) * maxChunksPerPacket;
}
ByteBuffer pktBuf = ByteBuffer.allocate(pktSize);
//循环发送数据块中的校验块
while (endOffset > offset) {
manageOsCache();
long len = sendChunks(pktBuf, maxChunksPerPacket,
streamForSendChunks);
offset += len;
totalRead += len + ((len + bytesPerChecksum - 1)/bytesPerChecksum*
checksumSize);
seqno++;
}
try {
out.writeInt(0); // mark the end of block
out.flush();
} catch (IOException e) { //socket error
throw ioeToSocketException(e);
}
}
catch(RuntimeException e){
LOG.error("unexpected exception sending block", e);thrownewIOException("unexpected runtime exception", e);}finally{if(clientTraceFmt !=null){finallong endTime =System.nanoTime();ClientTraceLog.info(String.format(clientTraceFmt, totalRead, initialOffset, endTime - startTime));}
close();}
blockReadFully =(initialOffset ==0&& offset >= blockLength);return totalRead;}
在这个方法有两个输出流对象参数,一个是DataOutputStream类型的out对象,一个是OutputStream类型的baseStream对象,在 DataXceiver.readBlock()
方法中可以看到,其实out对象就是对baseStream对象的封装,baseStream主要用于向客户端发送数据的“零拷贝”过程中(稍后分析)。
sendBlock方法首先进行一些发送数据前的预处理,比如通过本地方法调用来调用Linux的 posix_fadvise
函数来声明blockInfd的访问方式为顺序访问,调用manageOsCache()
方法设置操作系统缓存等。然后对客户端读请求发送应答头部信息,包含数据校验类型,校验块大小,偏移量,其中对于客户端请求,偏移量是必选参数。为什么说偏移量是必选的?因为BlockSender不但被用于支持客户端读数据,也用于数据块复制中。数据块复制由于是对整个数据块进行的操作,也就不需要提供数据块内的偏移量,但是对于客户端来说,偏移量是一个必须的参数。
输出完响应头部信息后,就可以开始向客户端输出数据块数据了。输出数据有两种方式,一种是传统的传输方式,即先从数据块文件中读入文件数据,然后通过Socket输出流输出,这种方式容易理解,但是效率比较低。另外一种方式是Linux/Unix中的“零拷贝”输出,关于“零拷贝输出”可以参考 通过零拷贝实现有效数据传输 ,不论是传统的输出方式,还是“零拷贝”输出都是循环调用 BlockSender.sendChunks()
方法进行输出的,因为一个数据块大小可能比较大,DataNode节点会分多次分别将这个数据块的数据发送完成,每次发送都发送一个数据包,这个数据包有包长度,在数据块中的偏移,序列号等信息。 Block.sendChunks()
方法的代码如下:
private int sendChunks(ByteBuffer pkt, int maxChunks, OutputStream out)
throws IOException {
// Sends multiple chunks in one packet with a single write().
int len = (int) Math.min(endOffset - offset,
(((long) bytesPerChecksum) * ((long) maxChunks)));
// truncate len so that any partial chunks will be sent as a final packet.
// this is not necessary for correctness, but partial chunks are
// ones that may be recomputed and sent via buffer copy, so try to minimize
// those bytes
if (len > bytesPerChecksum && len % bytesPerChecksum != 0) {
len -= len % bytesPerChecksum;
}
if (len == 0) {
return 0;
}
int numChunks = (len + bytesPerChecksum - 1)/bytesPerChecksum;
int packetLen = len + numChunks*checksumSize + 4;
pkt.clear();
// write packet header,应答包头部
pkt.putInt(packetLen);//包长度
pkt.putLong(offset);//偏移量
pkt.putLong(seqno);//序列号
pkt.put((byte)((offset + len >= endOffset) ? 1 : 0));//最后应答包标识,该数据包是否是应答的最后一个数据包
//why no ByteBuf.putBoolean()?
pkt.putInt(len);//数据长度
int checksumOff = pkt.position();
int checksumLen = numChunks * checksumSize;//校验信息的长度
byte[] buf = pkt.array();//获取字节缓冲区对应的字节数组
if (checksumSize > 0 && checksumIn != null) {
try {
checksumIn.readFully(buf, checksumOff, checksumLen);//将校验信息发送写到发送缓冲区中
} catch (IOException e) {
LOG.warn(" Could not read or failed to veirfy checksum for data" +
" at offset " + offset + " for block " + block + " got : "
+ StringUtils.stringifyException(e));
IOUtils.closeStream(checksumIn);
checksumIn = null;
if (corruptChecksumOk) {
if (checksumOff < checksumLen) {
// Just fill the array with zeros.
Arrays.fill(buf, checksumOff, checksumLen, (byte) 0);
}
} else {
throw e;
}
}
}
int dataOff = checksumOff + checksumLen;//数据部分的偏移
if (blockInPosition < 0) {//blockInPosition < 0表示不能进行“零拷贝”传输
//normal transfer,进行传统的传输,即先将数据从文件读入内存缓冲区,再将数据通过Socket发送给客户端
IOUtils.readFully(blockIn, buf, dataOff, len);
if (verifyChecksum) {
int dOff = dataOff;
int cOff = checksumOff;
int dLeft = len;
for (int i=0; i<numChunks; i++) {
checksum.reset();int dLen =Math.min(dLeft, bytesPerChecksum);
checksum.update(buf, dOff, dLen);if(!checksum.compare(buf, cOff)){thrownewChecksumException("Checksum failed at "+(offset + len - dLeft), len);}
dLeft -= dLen;
dOff += dLen;
cOff += checksumSize;}}// only recompute checksum if we can't trust the meta data due to // concurrent writesif(memoizedBlock.hasBlockChanged(len)){//如果数据发生了变化ChecksumUtil.updateChunkChecksum(
buf, checksumOff, dataOff, len, checksum
);}try{out.write(buf,0, dataOff + len);}catch(IOException e){throw ioeToSocketException(e);}}else{try{//use transferTo(). Checks on out and blockIn are already done. //使用transferTo()方法需要获得Socket的输出流和输入文件通道SocketOutputStream sockOut =(SocketOutputStream)out;FileChannel fileChannel =((FileInputStream) blockIn).getChannel();if(memoizedBlock.hasBlockChanged(len)){//有竞争存在//文件发生变化,假定出现读写竞争
fileChannel.position(blockInPosition);IOUtils.readFileChannelFully(
fileChannel,
buf,
dataOff,
len
);//计算校验和ChecksumUtil.updateChunkChecksum(
buf, checksumOff, dataOff, len, checksum
);
sockOut.write(buf,0, dataOff + len);}else{//first write the packet,写数据和包校验信息
sockOut.write(buf,0, dataOff);// no need to flush. since we know out is not a buffered stream.零拷贝发送数据
sockOut.transferToFully(fileChannel, blockInPosition, len);}
blockInPosition += len;}catch(IOException e){/* exception while writing to the client (well, with transferTo(),
* it could also be while reading from the local file).
*/throw ioeToSocketException(e);}}if(throttler !=null){// rebalancing so throttle
throttler.throttle(packetLen);//调用节流器对象的throttle()方法}return len;}
该方法有三个参数,ByteBuffer类型的pkt参数为发送缓冲区,不论是传统输出方式还是“零拷贝”输出方式,都需要发送包信息,在使用传统发送方式时,pkt中有包信息和数据信息,在“零拷贝”方式中,pkt则包含包信息。第二个参数是maxChunks,表示要发送几个校验块,第三个参数是输出流对象。 BlockSender.sendChunks()
方法逻辑比较清晰,在发送缓冲区中写入包头部信息,然后是校验信息,最后通过 blockInPosition
变量来区分是通过传统输出方式发送还是“零拷贝”方式发送, blockInPosition
变量默认是-1,在BlockSender.sendBlock()
方法中可能会通过 blockInPosition = fileChannel.position();
这行代码改变,因为这行代码是在判断通过”零拷贝“方式发送后执行的,如果 blockInPosition
为-1,那么小于零,说明在BlockSender.sendBlock()
方法中并未改变,如果值改变了,那么一定是一个非负值,因为 FileChannel.position()
方法的返回值是一个非负值,这个返回值代表FileChannel中的变量position的位置(请参考Java NIO中的部分)。
总结
当客户端进行数据读取时,先访问NameNode,通过调用ClientProtocol.getBlockLocations()
方法来获取到要读取文件的数据块所在的DataNode节点,然后客户端联系DataNode节点来读取文件的数据块,整个过程比较复杂的就是对DataNode节点的数据请求。
Reference
通过零拷贝实现有效数据传输: http://www.ibm.com/developerworks/cn/java/j-zerocopy/
一般文件I/O用法建议:http://www.cnblogs.com/ggzwtj/archive/2011/10/11/2207726.html
《Hadoop技术内幕:深入理解Hadoop Common和HDFS架构设计与实现原理》
Hadoop源码分析之读文件时NameNode和DataNode的处理过程的更多相关文章
- Hadoop源码分析之数据节点的握手,注册,上报数据块和心跳
转自:http://www.it165.net/admin/html/201402/2382.html 在上一篇文章Hadoop源码分析之DataNode的启动与停止中分析了DataNode节点的启动 ...
- Yii2.0源码分析之——控制器文件分析(Controller.php)创建动作、执行动作
在Yii中,当请求一个Url的时候,首先在application中获取request信息,然后由request通过urlManager解析出route,再在Module中根据route来创建contr ...
- 鸿蒙内核源码分析(静态链接篇) | 完整小项目看透静态链接过程 | 百篇博客分析OpenHarmony源码 | v54.01
百篇博客系列篇.本篇为: v54.xx 鸿蒙内核源码分析(静态链接篇) | 完整小项目看透静态链接过程 | 51.c.h.o 下图是一个可执行文件编译,链接的过程. 本篇将通过一个完整的小工程来阐述E ...
- Tomcat源码分析——SERVER.XML文件的加载与解析
前言 作为Java程序员,对于Tomcat的server.xml想必都不陌生.本文基于Tomcat7.0的Java源码,对server.xml文件是如何加载和解析的进行分析. 加载 server.xm ...
- Hadoop源码分析之Configuration
转自:http://www.it165.net/admin/html/201312/2178.html org.apache.hadoop.conf.Configuration类是Hadoop所有功能 ...
- Tomcat源码分析——server.xml文件的加载
前言 作为Java程序员,对于tomcat的server.xml想必都不陌生.本文基于Tomcat7.0的Java源码,对server.xml文件是如何加载的进行分析. 源码分析 Bootstrap的 ...
- HDFS源码分析之FSImage文件内容(一)总体格式
FSImage文件是HDFS中名字节点NameNode上文件/目录元数据在特定某一时刻的持久化存储文件.它的作用不言而喻,在HA出现之前,NameNode因为各种原因宕机后,若要恢复或在其他机器上重启 ...
- gRPC源码分析0-导读
gRPC是Google开源的新一代RPC框架,官网是http://www.grpc.io.正式发布于2016年8月,技术栈非常的新,基于HTTP/2,netty4.1,proto3.虽然目前在工程化方 ...
- CodeIgniter框架——源码分析之入口文件index.php
CodeIgniter框架的入口文件主要是配置开发环境,定义目录常量,加载CI的核心类core/CodeIgniter.php. 在index.php中,CI首先做的事情就是设置PHP的错误报告, ...
随机推荐
- Quartz.Net的使用(简单配置方法)定时任务框架
Quartz.dll 安装nuget在线获取dll包管理器,从中获取最新版 Quartz.Net是一个定时任务框架,可以实现异常灵活的定时任务,开发人员只要编写少量的代码就可以实现“每隔1小时执行”. ...
- 在 HTML 中使用JavaScript
<script>元素 属性 async:可选.async 属性规定一旦脚本可用,则会异步执行,表示应该立即下载脚本,但不妨碍页面中的其他操作,比如下载其他资源或等待加载其他脚本.a ...
- SQL Server 性能调优(方法论)【转】
目录 确定思路 wait event的基本troubleshooting 虚拟文件信息(virtual file Statistics) 性能指标 执行计划缓冲的使用 总结 性能调优很难有一个固定的理 ...
- js经常使用功能代码
js经常使用功能代码(持续更新): 1---折叠与展开 <input id="btnDisplay" type="button" class=" ...
- 通用的sql语句
1.插入: INSERT INTO 表名称 VALUES (值1, 值2,....) 我们也可以指定所要插入数据的列: INSERT INTO table_name (列1, 列2,...) VALU ...
- 虚拟机VMware下CentOS6.5安装教程图文详解(VMnet8)
(写在最前面:如果你下载的iso文件 CentOS-6.*-x86_64-minimal.iso 系列,那么需要这么安装:https://blog.csdn.net/lixianlin/article ...
- fatal error LNK1123: 转换到 COFF 期间失败:文件无效或损坏
问题出现背景: 原本电脑里是装着VS2015的,其使用的是.NET 4.5,当再安装VS2010之后,不能与当前的.NET平台兼容.卸载VS2015时,不会恢复.NET 4.0. l 当VS2015安 ...
- javascript通用函数库
/* -------------- 函数检索 -------------- trim函数: trim() lTrim() rTrim() 校验字符串是否 ...
- mosquitto ---mosquitto-auth-plug
https://github.com/jpmens/mosquitto-auth-plug This is a plugin to authenticate and authorize Mosquit ...
- C#基础—不安全代码(unsafe code)
1.为何要有unsafe 也许是为了实现CLR类型安全的目标吧,默认情况下,C#没有提供指针的使用算法,但是有些情况下也可能需要指针这样直接访问内存的东西(虽然目前我还没有用过),但是有时候程序员非常 ...