分享

hbase源码系列(七)Snapshot的过程

本帖最后由 坎蒂丝_Swan 于 2014-12-29 13:00 编辑

问题导读
1.为什么要做Snapshot?
2.在snapshotEnabledTable方法中在线的表是怎么备份的?






在看这一章之前,建议大家先去看一下snapshot的使用。可能有人会有疑问为什么要做Snapshot,hdfs不是自带了3个备份吗,这是个很大的误区,要知道hdfs的3个备份是用于防止网络传输中的失败或者别的异常情况导致数据块丢失或者不正确,它不能避免人为的删除数据导致的后果。它就想是给数据库做备份,尤其是做删除动作之前,不管是hbase还是hdfs,请经常做Snapshot,否则哪天手贱了。。。

直接进入主题吧,上代码。

  1. public void takeSnapshot(SnapshotDescription snapshot) throws IOException {
  2.     // 清空之前完成的备份和恢复的任务
  3.     cleanupSentinels();
  4.     // 设置snapshot的版本
  5.     snapshot = snapshot.toBuilder().setVersion(SnapshotDescriptionUtils.SNAPSHOT_LAYOUT_VERSION)
  6.         .build();
  7.     // if the table is enabled, then have the RS run actually the snapshot work
  8.     TableName snapshotTable = TableName.valueOf(snapshot.getTable());
  9.     AssignmentManager assignmentMgr = master.getAssignmentManager();
  10.     //根据表的状态选择snapshot的类型
  11.     if (assignmentMgr.getZKTable().isEnabledTable(snapshotTable)) {
  12.       snapshotEnabledTable(snapshot);
  13.     }
  14.     // 被禁用的表走这个方法
  15.     else if (assignmentMgr.getZKTable().isDisabledTable(snapshotTable)) {
  16.       snapshotDisabledTable(snapshot);
  17.     } else {
  18.       throw new SnapshotCreationException("Table is not entirely open or closed", tpoe, snapshot);
  19.     }
  20.   }
复制代码

从代码上看得出来,启用的表和被禁用的表走的是两个不同的方法。

Snapshot启用的表
先看snapshotEnabledTable方法吧,看看在线的表是怎么备份的。

  1. private synchronized void snapshotEnabledTable(SnapshotDescription snapshot)
  2.       throws HBaseSnapshotException {
  3.     // snapshot准备工作
  4.     prepareToTakeSnapshot(snapshot);
  5.    
  6.     // new一个handler
  7.     EnabledTableSnapshotHandler handler =
  8.         new EnabledTableSnapshotHandler(snapshot, master, this);
  9.     //通过handler线程来备份
  10.     snapshotTable(snapshot, handler);
  11. }
复制代码

这里就两步,先去看看snapshot前的准备工作吧,F3进入prepareToTakeSnapshot方法。这个方法里面也没干啥,就是检查一下是否可以对这个表做备份或者恢复的操作,然后就会重建这个工作目录,这个工作目录在.hbase-snapshot/.tmps下面,每个snapshot都有自己的目录。

在snapshotTable里面把就线程提交一下,让handler来处理了。

  1. handler.prepare();
  2. this.executorService.submit(handler);
  3. this.snapshotHandlers.put(TableName.valueOf(snapshot.getTable()), handler);
复制代码


这些都不是重点,咱到handler那边去看看吧,EnabledTableSnapshotHandler是继承TakeSnapshotHandler的,prepare方法和process方法都一样,区别在于snapshotRegions方法被重写了。

看prepare方法还是检查表的定义文件在不在,我们直接进入process方法吧。

  1. // 把snapshot的信息写入到工作目录
  2.       SnapshotDescriptionUtils.writeSnapshotInfo(snapshot, workingDir, this.fs);
  3.       // 开一个线程去复制表信息文件
  4.       new TableInfoCopyTask(monitor, snapshot, fs, rootDir).call();
  5.       monitor.rethrowException();
  6.       //查找该表相关的region和位置
  7.       List<Pair<HRegionInfo, ServerName>> regionsAndLocations =
  8.           MetaReader.getTableRegionsAndLocations(this.server.getCatalogTracker(),
  9.               snapshotTable, false);
  10.       // 开始snapshot
  11.       snapshotRegions(regionsAndLocations);
  12.       // 获取serverNames列表,后面的校验snapshot用到
  13.       Set<String> serverNames = new HashSet<String>();
  14.       for (Pair<HRegionInfo, ServerName> p : regionsAndLocations) {
  15.         if (p != null && p.getFirst() != null && p.getSecond() != null) {
  16.           HRegionInfo hri = p.getFirst();
  17.           if (hri.isOffline() && (hri.isSplit() || hri.isSplitParent())) continue;
  18.           serverNames.add(p.getSecond().toString());
  19.         }
  20.       }
  21.       // 检查snapshot是否合格
  22.       status.setStatus("Verifying snapshot: " + snapshot.getName());
  23.       verifier.verifySnapshot(this.workingDir, serverNames);
  24. // 备份完毕之后,把临时目录转移到正式的目录
  25.       completeSnapshot(this.snapshotDir, this.workingDir, this.fs);
复制代码


  1、写一个.snapshotinfo文件到工作目录下
  2、把表的定义信息写一份到工作目录下,即.tabledesc文件
  3、查找和表相关的Region Server和机器
  4、开始备份
  5、检验snapshot的结果
  6、确认没问题了,就把临时目录rename到正式目录

我们直接到备份这一步去看吧,方法在EnabledTableSnapshotHandler里面,重写了。

  1. // 用分布式事务来备份在线的,太强悍了
  2.     Procedure proc = coordinator.startProcedure(this.monitor, this.snapshot.getName(),
  3.       this.snapshot.toByteArray(), Lists.newArrayList(regionServers));
  4.     try {
  5.       // 等待完成
  6.       proc.waitForCompleted();
  7.     // 备份split过的region
  8.       Path snapshotDir = SnapshotDescriptionUtils.getWorkingSnapshotDir(snapshot, rootDir);
  9.       for (Pair<HRegionInfo, ServerName> region : regions) {
  10.         HRegionInfo regionInfo = region.getFirst();
  11.         if (regionInfo.isOffline() && (regionInfo.isSplit() || regionInfo.isSplitParent())) {
  12.           if (!fs.exists(new Path(snapshotDir, regionInfo.getEncodedName()))) {
  13.             LOG.info("Take disabled snapshot of offline region=" + regionInfo);
  14.             snapshotDisabledRegion(regionInfo);
  15.           }
  16.         }
  17.       }
复制代码

这里用到一个分布式事务,这里被我叫做分布式事务,我也不知道它是不是事务,但是Procedure这个词我真的不好翻译,叫过程也不合适。

分布式事务
我们进入ProcedureCoordinator的startProcedure看看吧。

  1. Procedure proc = createProcedure(fed, procName, procArgs,expectedMembers);
  2. if (!this.submitProcedure(proc)) {
  3.       LOG.error("Failed to submit procedure '" + procName + "'");
  4.       return null;
  5. }
复制代码

先创建Procedure,然后提交它,这块没什么特别的,继续深入进去submitProcedure方法也找不到什么有用的信息,我们得回到Procedure类里面去,它是一个Callable的类,奥秘就在call方法里面。
  1. final public Void call() {
  2.     try {
  3.       //在acquired节点下面建立实例节点
  4.       sendGlobalBarrierStart();
  5.       // 等待所有的rs回复
  6.       waitForLatch(acquiredBarrierLatch, monitor, wakeFrequency, "acquired");
  7.       //在reached节点下面建立实例节点
  8.       sendGlobalBarrierReached();
  9.       //等待所有的rs回复
  10.       waitForLatch(releasedBarrierLatch, monitor, wakeFrequency, "released");
  11.     } finally {
  12.       sendGlobalBarrierComplete();
  13.       completedLatch.countDown();
  14.     }
  15. }
复制代码

从sendGlobalBarrierStart开始看吧,里面就一句话。
  1.   coord.getRpcs().sendGlobalBarrierAcquire(this, args, Lists.newArrayList(this.acquiringMembers));
复制代码

再追杀下去。
  1. final public void sendGlobalBarrierAcquire(Procedure proc, byte[] info, List<String> nodeNames)
  2.       throws IOException, IllegalArgumentException {
  3.     String procName = proc.getName();
  4.     // 获取abort节点的名称
  5.     String abortNode = zkProc.getAbortZNode(procName);
  6.     try {
  7.       // 如果存在abort节点,就广播错误,中断该过程
  8.       if (ZKUtil.watchAndCheckExists(zkProc.getWatcher(), abortNode)) {
  9.         abort(abortNode);
  10.       }
  11.     } catch (KeeperException e) {throw new IOException("Failed while watching abort node:" + abortNode, e);
  12.     }
  13.     // 获得acquire节点名称
  14.     String acquire = zkProc.getAcquiredBarrierNode(procName);
  15.   try {
  16.       // 创建acquire节点,info信息是Snapshot的信息,包括表名
  17.       byte[] data = ProtobufUtil.prependPBMagic(info);
  18.       ZKUtil.createWithParents(zkProc.getWatcher(), acquire, data);
  19.     // 监控acquire下面的节点,发现指定的节点,就报告给coordinator
  20.       for (String node : nodeNames) {
  21.         String znode = ZKUtil.joinZNode(acquire, node);if (ZKUtil.watchAndCheckExists(zkProc.getWatcher(), znode)) {
  22.           coordinator.memberAcquiredBarrier(procName, node);
  23.         }
  24.       }
  25.     } catch (KeeperException e) {
  26.       throw new IOException("Failed while creating acquire node:" + acquire, e);
  27.     }
  28.   }
复制代码


  1、首先是检查abortNode ,什么是abortNode ?每个procName在zk下面都有一个对应的节点,比如snapshot,然后在procName下面又分了acquired、reached、abort三个节点。检查abort节点下面有没有当前的实例。
  2、在acquired节点为该实例创建节点,创建实例节点的时候,把SnapshotDescription的信息(在EnabledTableSnapshotHandler类里面通过this.snapshot.toByteArray()传进去的)放了进去,创建完成之后,在该实例节点下面监控各个Region Server的节点。如果发现已经有了,就更新Procedure中的acquiringMembers列表和inBarrierMembers,把节点从
acquiringMembers中删除,然后添加到inBarrierMembers列表当中。
  3、到这一步服务端的工作就停下来了,等到所有RS接收到指令之后通过实例节点当中保存的表信息找到相应的region创建子过程,子过程在acquired节点下创建节点。
  4、收到所有RS的回复之后,它才会开始在reached节点创建实例节点,然后继续等待。
  5、RS完成任务之后,在reached的实例节点下面创建相应的节点,然后回复。
  6、在确定所有的RS都完成工作之后,清理zk当中的相应proName节点。
  注意:在这个过程当中,有任务的错误,都会在abort节点下面建立该实例的节点,RS上面的子过程一旦发现abort存在该节点的实例,就会取消该过程。

Snapshot这块在Region Server是由RegionServerSnapshotManager类里面的ProcedureMemberRpcs负责监测snapshot下面的节点变化,当发现acquired下面有实例之后,启动新任务。

  1. public ZKProcedureMemberRpcs(final ZooKeeperWatcher watcher, final String procType)
  2.       throws KeeperException {
  3.     this.zkController = new ZKProcedureUtil(watcher, procType) {
  4.       @Override
  5.       public void nodeCreated(String path) {
  6.         if (!isInProcedurePath(path)) {
  7.           return;
  8.         }
  9.         String parent = ZKUtil.getParent(path);
  10.         // if its the end barrier, the procedure can be completed
  11.         if (isReachedNode(parent)) {
  12.           receivedReachedGlobalBarrier(path);
  13.           return;
  14.         } else if (isAbortNode(parent)) {
  15.           abort(path);
  16.           return;
  17.         } else if (isAcquiredNode(parent)) {
  18.           startNewSubprocedure(path);
  19.         } else {
  20.           LOG.debug("Ignoring created notification for node:" + path);
  21.         }
  22.       }
  23.      };
  24.   }
复制代码

这块折叠起来,不是咱们的重点,让大家看看而已。我们直接进入Subprocedure这个类里面看看吧。
  1. final public Void call() {
  2.    
  3.     try {
  4.       // 目前是什么也没干
  5.       acquireBarrier();
  6.       // 在acquired的实例节点下面建立rs的节点
  7.       rpcs.sendMemberAcquired(this);
  8.       // 等待reached的实例节点的建立
  9.       waitForReachedGlobalBarrier();
  10.      // 干活
  11.       insideBarrier();
  12.       // 活干完了
  13.       rpcs.sendMemberCompleted(this);
  14.      } catch (Exception e) {
  15.      } finally {
  16.           releasedLocalBarrier.countDown();
  17.      }
  18. }
复制代码

insideBarrier的实现在FlushSnapshotSubprocedure这个类里面,调用了flushSnapshot(),这个方法给每个region都开一个线程去提交。
  1. for (HRegion region : regions) {
  2.       taskManager.submitTask(new RegionSnapshotTask(region));
  3. }
复制代码

Snapshot在线的region
我们接下来看看RegionSnapshotTask的call方法

  1. public Void call() throws Exception {
  2.       // 上锁,暂时不让读了
  3.       region.startRegionOperation();
  4.       try {
  5.         region.flushcache();
  6.         region.addRegionToSnapshot(snapshot, monitor);
  7.       } finally {
  8.         LOG.debug("Closing region operation on " + region);
  9.         region.closeRegionOperation();
  10.       }
  11.       return null;
  12.     }
  13. }
复制代码

在对region操作之前,先上锁,不让读了。然后就flushCache,这个方法很大,也好难懂哦,不过我们还是要迎接困难上.
  1. MultiVersionConsistencyControl.WriteEntry w = null;
  2.     this.updatesLock.writeLock().lock();
  3.     long flushsize = this.memstoreSize.get();
  4.     List<StoreFlushContext> storeFlushCtxs = new ArrayList<StoreFlushContext>(stores.size());
  5.     long flushSeqId = -1L;
  6.     //先flush日志,再flush memstore到文件
  7.     try {
  8.       // Record the mvcc for all transactions in progress.
  9.       w = mvcc.beginMemstoreInsert();
  10.       mvcc.advanceMemstore(w);
  11.       if (wal != null) {
  12.         //准备flush日志,进入等待flush的队列,这个startSeqId很重要,在恢复的时候就靠它了,它之前的日志就是已经flush过了,不用恢复
  13.         Long startSeqId = wal.startCacheFlush(this.getRegionInfo().getEncodedNameAsBytes());
  14.         if (startSeqId == null) {
  15.           return false;
  16.         }
  17.         flushSeqId = startSeqId.longValue();
  18.       } else {
  19.         flushSeqId = myseqid;
  20.       }
  21.       for (Store s : stores.values()) {
  22.         storeFlushCtxs.add(s.createFlushContext(flushSeqId));
  23.       }
  24.       // 给MemStore做个snapshot,它的内部是两个队列,实际是从一个经常访问的队列放到另外一个不常访问的队列,那个队列名叫snapshot
  25.       for (StoreFlushContext flush : storeFlushCtxs) {
  26.         flush.prepare();
  27.       }
  28.     } finally {
  29.       this.updatesLock.writeLock().unlock();
  30.     }
  31.     // 同步未flush的日志到硬盘上
  32.     if (wal != null && !shouldSyncLog()) {
  33.       wal.sync();
  34.     }
  35.     // 等待日志同步完毕
  36.     mvcc.waitForRead(w);
  37.     boolean compactionRequested = false;
  38.     try {//把memstore中的keyvalues全部flush到storefile保存在临时目录当中,把flushSeqId追加到storefile里
  39.       for (StoreFlushContext flush : storeFlushCtxs) {
  40.         flush.flushCache(status);
  41.       }
  42.       // 把之前生成在临时目录的文件转移到正式目录
  43.       for (StoreFlushContext flush : storeFlushCtxs) {
  44.         boolean needsCompaction = flush.commit(status);
  45.         if (needsCompaction) {
  46.           compactionRequested = true;
  47.         }
  48.       }
  49.       storeFlushCtxs.clear();
  50.       // flush之后,就要减掉相应的memstore的大小
  51.       this.addAndGetGlobalMemstoreSize(-flushsize);
复制代码


  1、获取WAL日志的flushId(要写入到hfile当中,以后恢复的时候,要拿日志的flushId和hfile的flushId对比,小于hfile的flushId的就不用恢复了)
  2、给MemStore的做snapshot,从kvset集合转移到snapshot集合
  3、同步日志,写入到硬盘
  4、把MemStore的的snapshot集合当中的内容写入到hfile当中,MemStore当中保存的是KeyValue的集合,写入其实就是一个循环,调用StoreFile.Writer的append方法追加。
  5、上一步的生成的文件是保存在临时目录中的,转移到正式的目录当中
  6、更新MemStore当中的大小

好,我们继续看addRegionToSnapshot方法,好累啊,尼玛,这么多步骤。

  1. public void addRegionToSnapshot(SnapshotDescription desc,
  2.       ForeignExceptionSnare exnSnare) throws IOException {// 获取工作目录
  3.     Path rootDir = FSUtils.getRootDir(this.rsServices.getConfiguration());
  4.     Path snapshotDir = SnapshotDescriptionUtils.getWorkingSnapshotDir(desc, rootDir);
  5.     // 1. 在工作目录创建region目录和写入region的信息
  6.     HRegionFileSystem snapshotRegionFs = HRegionFileSystem.createRegionOnFileSystem(conf,
  7.         this.fs.getFileSystem(), snapshotDir, getRegionInfo());
  8.     // 2. 为hfile创建引用
  9.     for (Store store : stores.values()) {
  10.       // 2.1. 分列族为store创建引用目录,每个store属于不同的列族
  11.       Path dstStoreDir = snapshotRegionFs.getStoreDir(store.getFamily().getNameAsString());
  12.       List<StoreFile> storeFiles = new ArrayList<StoreFile>(store.getStorefiles());// 2.2. 遍历hfile,然后创建引用
  13.       int sz = storeFiles.size();
  14.       for (int i = 0; i < sz; i++) {
  15.         StoreFile storeFile = storeFiles.get(i);
  16.         Path file = storeFile.getPath();
  17.         Path referenceFile = new Path(dstStoreDir, file.getName());
  18.         boolean success = true;
  19.         if (storeFile.isReference()) {
  20.           // 把旧的引用文件的内容写入到新的引用文件当中
  21.           storeFile.getFileInfo().getReference().write(fs.getFileSystem(), referenceFile);
  22.         } else {
  23.           // 创建一个空的引用文件
  24.           success = fs.getFileSystem().createNewFile(referenceFile);
  25.         }
  26.         if (!success) {
  27.           throw new IOException("Failed to create reference file:" + referenceFile);
  28.         }
  29.       }
  30.     }
  31.   }
复制代码


在工作目录在.hbase-snapshot/.tmps/snapshotName/region/familyName/下面给hfile创建引用文件。在创建引用文件的时候,还要先判断一下这个所谓的hfile是不是真的hfile,还是它本身就是一个引用文件了。
  如果已经是引用文件的话,把旧的引用文件里面的内容写入到新的引用文件当中。
  如果是一个正常的hfile的话,就创建一个空的引用文件即可,以后我们可以通过它的名字找到它在snapshot下面相应的文件。
  okay,到这里,每个RS的工作都完成了。

备份split过的region
完成执行分布式事务,就是备份split过的region。

  1. if (regionInfo.isOffline() && (regionInfo.isSplit() || regionInfo.isSplitParent())) {
  2.     if (!fs.exists(new Path(snapshotDir, regionInfo.getEncodedName()))) {
  3.           LOG.info("Take disabled snapshot of offline region=" + regionInfo);
  4.           snapshotDisabledRegion(regionInfo);
  5.      }
  6. }
复制代码
  1. protected void snapshotDisabledRegion(final HRegionInfo regionInfo)
  2.       throws IOException {
  3.     // 创建新的region目录和region信息
  4.     HRegionFileSystem regionFs = HRegionFileSystem.createRegionOnFileSystem(conf, fs,
  5.       workingDir, regionInfo);
  6.      // 把region下的recovered.edits目录的文件复制snapshot的对应region下面
  7.     Path regionDir = HRegion.getRegionDir(rootDir, regionInfo);
  8.     Path snapshotRegionDir = regionFs.getRegionDir();
  9.     new CopyRecoveredEditsTask(snapshot, monitor, fs, regionDir, snapshotRegionDir).call();
  10.    
  11.     // 给每个列族的下面的文件创建引用,所谓引用就是一个同名的空文件
  12.     new ReferenceRegionHFilesTask(snapshot, monitor, regionDir, fs, snapshotRegionDir).call();
  13. }
复制代码


备份启用的表,现在已经结束了,但是备份禁用的表吧,前面说了区别是snapshotRegions方法,但是方法除了做一些准备工作之外,就是snapshotDisabledRegion。。。。所以snapshot到这里就完了,下面我们再回顾一遍吧。

  1、进行snapshot之前的准备,创建目录,复制一些必要的信息文件等。
  2、对于启用的表,启动分布式事务,RS接到任务,flush掉WAL日志和MemStore的数据,写入文件。
  3、为hfile创建引用文件,这里的引用文件居然是空的文件,而且名字一样,它不是真的备份hfile,这是什么回事呢?这个要到下一章,从snapshot中恢复,才能弄明白了,这个和hbase的归档文件机制有关系,hbase删除文件的时候,不是直接删除,而是把它先放入archive文件夹内。



hbase源码系列(二)HTable 探秘hbase源码系列(三)Client如何找到正确的Region Server
hbase源码系列(四)数据模型-表定义和列族定义的具体含义
hbase源码系列(五)Trie单词查找树
hbase源码系列(六)HMaster启动过程
hbase源码系列(七)Snapshot的过程
hbase源码系列(八)从Snapshot恢复表
hbase源码系列(九)StoreFile存储格式
hbase源码系列(十)HLog与日志恢复
hbase源码系列(十一)Put、Delete在服务端是如何处理?
hbase源码系列(十二)Get、Scan在服务端是如何处理?
hbase源码系列(十三)缓存机制MemStore与Block Cache
hbase源码之如何查询出来下一个KeyValue
hbase源码Compact和Split


欢迎加入about云群90371779322273151432264021 ,云计算爱好者群,亦可关注about云腾讯认证空间||关注本站微信

没找到任何评论,期待你打破沉寂

您需要登录后才可以回帖 登录 | 立即注册

本版积分规则

关闭

推荐上一条 /2 下一条