Chinaunix首页 | 论坛 | 博客
  • 博客访问: 7093417
  • 博文数量: 3857
  • 博客积分: 6409
  • 博客等级: 准将
  • 技术积分: 15948
  • 用 户 组: 普通用户
  • 注册时间: 2008-09-02 16:48
个人简介

迷彩 潜伏 隐蔽 伪装

文章分类

全部博文(3857)

文章存档

2017年(5)

2016年(63)

2015年(927)

2014年(677)

2013年(807)

2012年(1241)

2011年(67)

2010年(7)

2009年(36)

2008年(28)

分类: 架构设计与优化

2013-10-09 10:38:32

在这一个章节中,我们来追踪一下,用户提交了一个作业之后,如何从Mesos之中获取资源?

当然我们还是接着我上一中我们追踪到,FrameworkScheduler的代码,resourceOffers()函数

点击(此处)折叠或打开

  1. public void resourceOffers(SchedulerDriver d, List<Offer> offers) {
  2.     try {
  3.       synchronized(jobTracker) {

  4.         int numOffers = (int) offers.size();
  5.         double[] cpus = new double[numOffers];
  6.         double[] mem = new double[numOffers];

  7.         // Count up the amount of free CPUs and memory on each node
  8.         for (int i = 0; i < numOffers; i++) {
  9.           Offer offer = offers.get(i);
  10.           LOG.info("Got resource offer " + offer.getId());
  11.           cpus[i] = getResource(offer, "cpus");
  12.           mem[i] = getResource(offer, "mem");
  13.         }

  14.         // Assign tasks to the nodes in a round-robin manner, and stop when we
  15.         // are unable to assign a task to any node.
  16.         // We do this by keeping a linked list of indices of nodes for which
  17.         // we are still considering assigning tasks. Whenever we can't find a
  18.         // new task for a node, we remove it from the list. When the list is
  19.         // empty, no further assignments can be made. This algorithm was chosen
  20.         // because it minimizing the amount of scanning we need to do if we
  21.         // get a large set of offered nodes.
  22.         List<Integer> indices = new LinkedList<Integer>();
  23.         List<List<TaskInfo>> replies =
  24.             new ArrayList<List<TaskInfo>>(numOffers);
  25.         for (int i = 0; i < numOffers; i++) {
  26.           indices.add(i);
  27.           replies.add(new ArrayList<TaskInfo>());
  28.         }
  29.         while (indices.size() > 0) {
  30.           for (Iterator<Integer> it = indices.iterator(); it.hasNext();) {
  31.             int i = it.next();
  32.             Offer offer = offers.get(i);
  33.             TaskInfo task = findTask(
  34.                 offer.getSlaveId(), offer.getHostname(), cpus[i], mem[i]);
  35.             if (task != null) {
  36.               cpus[i] -= getResource(task, "cpus");
  37.               mem[i] -= getResource(task, "mem");
  38.               replies.get(i).add(task);
  39.             } else {
  40.               it.remove();
  41.             }
  42.           }
  43.         }

  44.         for (int i = 0; i < numOffers; i++) {
  45.           OfferID offerId = offers.get(i).getId();
  46.           Status status = d.launchTasks(offerId, replies.get(i));
  47.           if (status != Status.DRIVER_RUNNING) {
  48.             LOG.warn("SchedulerDriver returned irregular status: " + status);
  49.           }
  50.         }
  51.       }
  52.     } catch(Exception e) {
  53.       LOG.error("Error in resourceOffer", e);
  54.     }
  55.   }
这里代码的长度也不是很长,我们一步一步来分析,首先SchedulerProcess调用了本函数,将携带资源的offer传递了过来。
一)创建了两个数组cpus和mem,这两个数组下标跟offers list的下标是一致的,用他们保存了list中对应下标offer的cpu和mem的数量。
(二)为这个offers list创建了一个索引数组indices,其中保存的是offers list中的下标。
(三)创建了List>replies,其中存放的是分配给每个offer的所有任务信息的列表。
(五)按照indices中的顺序遍历,整个offers list,调用了findTask(
                offer.getSlaveId(), offer.getHostname(), cpus[i], mem[i])
我们重点看下这个函数的工作方式:

点击(此处)折叠或打开

  1. // Find a single task for a given node. Assumes JobTracker is locked.
  2.   private TaskInfo findTask(
  3.       SlaveID slaveId, String host, double cpus, double mem) {
  4.     if (cpus < cpusPerTask || mem < memPerTask) {
  5.       return null; // Too few resources are left on the node
  6.     }

  7.     TaskTrackerInfo ttInfo = getTaskTrackerInfo(host, slaveId);

  8.     // Pick whether to launch a map or a reduce based on available tasks
  9.     String taskType = null;
  10.     boolean haveMaps = canLaunchMap(host);
  11.     boolean haveReduces = canLaunchReduce(host);
  12.     //LOG.info("Looking at " + host + ": haveMaps=" + haveMaps +
  13.     // ", haveReduces=" + haveReduces);
  14.     if (!haveMaps && !haveReduces) {
  15.       return null;
  16.     } else if (haveMaps && !haveReduces) {
  17.       taskType = "map";
  18.     } else if (haveReduces && !haveMaps) {
  19.       taskType = "reduce";
  20.     } else {
  21.       float mapToReduceRatio = 1;
  22.       if (ttInfo.reduces.size() < ttInfo.maps.size() / mapToReduceRatio)
  23.         taskType = "reduce";
  24.       else
  25.         taskType = "map";
  26.     }
  27.     //LOG.info("Task type chosen: " + taskType);

  28.     // Get a Mesos task ID for the new task
  29.     TaskID mesosId = newMesosTaskId();

  30.     // Remember that it is launched
  31.     boolean isMap = taskType.equals("map");
  32.     if (isMap) {
  33.       unassignedMaps++;
  34.     } else {
  35.       unassignedReduces++;
  36.     }
  37.     MesosTask nt = new MesosTask(isMap, mesosId, host);
  38.     mesosIdToMesosTask.put(mesosId, nt);
  39.     ttInfo.add(nt);

  40.     LOG.info("Launching Mesos task " + mesosId.getValue() +
  41.              " as " + taskType + " on " + host);

  42.     // Create a task description to pass back to Mesos.
  43.     return TaskInfo.newBuilder()
  44.         .setTaskId(mesosId)
  45.         .setSlaveId(slaveId)
  46.         .setName("task " + mesosId.getValue() + " (" + taskType + ")")
  47.         .addResources(makeResource("cpus", cpusPerTask))
  48.         .addResources(makeResource("mem", memPerTask))
  49.         .setExecutor(getExecutorInfo())
  50.         .build();
  51.   }
1)判断该节点剩余的资源是否够分配一个任务
(2)获取该节点主机名对应的TaskTrackerInfo信息,这里TaskTracker仅仅是mesos中用来管理逻辑分配的一个数据结构,跟Hadoop没有关系
(3)那么我们如何获取到hadoop的job的task信息呢?我们来分析另外两个非常重要的函数

点击(此处)折叠或打开

  1. private boolean canLaunchMap(String host) {
  2.     // Check whether the TT is saturated on maps
  3.     TaskTrackerInfo ttInfo = ttInfos.get(host);
  4.     if (ttInfo == null) {
  5.       throw new RuntimeException("Expecting TaskTrackerInfo for host " + host);
  6.     }

  7.     if (ttInfo.maps.size() >= ttInfo.maxMaps) {
  8.       return false;
  9.     }

  10.     // Compute the total demand for maps to make sure we don't exceed it
  11.     Collection<JobInProgress> jobs = jobTracker.jobs.values();
  12.     int neededMaps = 0;
  13.     for (JobInProgress job : jobs) {
  14.       if (job.getStatus().getRunState() == JobStatus.RUNNING) {
  15.         neededMaps += job.pendingMaps();
  16.       }
  17.     }
  18.     // TODO (!!!): Count speculatable tasks and add them to neededMaps
  19.     // For now, we just add 1
  20.     if (jobs.size() > 0)
  21.       neededMaps += 1;

  22.     if (unassignedMaps < neededMaps) {
  23.       // 0. check for a failed map task to place. These tasks are not included
  24.       // in the "normal" lists of tasks in the JobInProgress object.
  25.       for (JobInProgress job: jobs) {
  26.         int state = job.getStatus().getRunState();
  27.         if (job.failedMaps != null && state == JobStatus.RUNNING) {
  28.           for (TaskInProgress tip : job.failedMaps) {
  29.             if (!tip.hasFailedOnMachine(host)) {
  30.               return true;
  31.             }
  32.           }
  33.         }
  34.       }

  35.       int maxLevel = Integer.MAX_VALUE;
  36.       // Look for a map with the required level
  37.       for (JobInProgress job: jobs) {
  38.         int state = job.getStatus().getRunState();
  39.         if (state == JobStatus.RUNNING) {
  40.           int availLevel = availableMapLevel(job, host, maxLevel);
  41.           if (availLevel != -1) {
  42.             lastMapWasLocal = (availLevel == 0);
  43.             return true;
  44.           }
  45.         }
  46.       }
  47.     }
1、从FrameworkSheduler保存的表:Map ttInfos中获取对应于该slave节点的TaskTrackerInfo,TaskTrackInfo中记载了什么东西呢?

点击(此处)折叠或打开

  1. private static class TaskTrackerInfo {
  2.     SlaveID mesosSlaveId;
  3.     List<MesosTask> maps = new LinkedList<MesosTask>();
  4.     List<MesosTask> reduces = new LinkedList<MesosTask>();
  5.     int maxMaps = 1;
  6.     int maxReduces = 1;

  7.     public TaskTrackerInfo(SlaveID mesosSlaveId) {
  8.       this.mesosSlaveId = mesosSlaveId;
  9.     }

  10.     void add(MesosTask nt) {
  11.       if (nt.isMap)
  12.         maps.add(nt);
  13.       else
  14.         reduces.add(nt);
  15.     }

  16.     public void remove(MesosTask nt) {
  17.       if (nt.isMap)
  18.         maps.remove(nt);
  19.       else
  20.         reduces.remove(nt);
  21.     }
是TaskTrackInfo的定义,它是FrameworkScheduler的一个内部类,记录
它所属的Slave节点的Slaveid
在该slave节点上属于该计算框架的map和reduce任务的列表,这些任务的标识是mesos内部产生的,对于计算框架是透明的。
里面定义了最大map和reduce队列的长度
杀掉超时的任务的方法。

2、获取了jobtracker上已经初始化的jobs的列表(这里非常的重要,就是在这个地方,mesos从hadoop中把用户提交的jobs拉了过来),遍列列表中的没有个JobInprogress,计算所有的job需要的map任务的总和neededmaps。

3、遍历jobs的列表中的每一个job,优先处理job的failmaps列表中任务,failmaps列表中的每一个任务的执行失败的主机列表,如果没有该salve节点,就返回true表明可以lauch一个map任务。

我们分析canLaunchMap这函数的目的是找到mesos跟hadoop交互的那个点,对于具体的任务查找方式,大家可以忽略,因为这些东西都是可以修改的。我们只需要记住就是在findTask->canLaunchMap之中,我们实现的基于mesos的调度器,去jobtracker上获取jobs的信息。

我们回到findTask函数之中,对于canLauchReduce的处理,大家可以自行解读,其实跟canLaunchMap大同小异。

(4)我们知道在该节点上是应该启动一个map和reduce任务之后,就产生一个新的TaskID为这个新任务。更新unassignedMaps或者unassignedReduces两个计数器。创建一个新的MesosTask对象:    MesosTask nt = new MesosTask(isMap, mesosId, host);将其加入到Map mesosIdToMesosTask这张表之中,便于查找。将该MesosTask加入到该salve节点对应TaskTrackInfo之中。同时返回一个TaskInfo对象,其中记录了任务的mesosid,slaveid,executorinfo等信息

ok,现在我们回到再上一层的resourceOffers函数:

(五)我们通过findtask()函数获取到了一个taskInfo,如果该TaskInfo不为空,我们继续寻找,为空说明资源已经使用完毕或者hadoop任务task都已经分配完毕,应该从indices之中将对应于该offer的下标擦除。
整个循环执行完毕之后,replies之中就记录了对应于每个offer的需要启动的任务信息的一个列表,但是这些任务信息都现在为止还仅仅是一个标志(我应该在哪个slave节点上,启动一个什么框架的什么任务(map或者reduce),并没有具体任务的信息

(六)接下来就是遍历replies,去启动这些任务,调用了SchedulerDriver.launchTasks()方法。调用我们之前sched.cpp之中launchTasks()方法,该方法会产生一条LanuchTasksMessage消息中包含了frameworkid、offerId、所有在该slave节点上的task的信息,一起发送给了Mesos master

(七)master接受到了LauchTasksMessage之后会调用这个消息的处理函数launchTasks。

点击(此处)折叠或打开

  1. void Master::launchTasks(const FrameworkID& frameworkId,
  2.                          const OfferID& offerId,
  3.                          const vector<TaskInfo>& tasks,
  4.                          const Filters& filters)
  5. {
  6.   Framework* framework = getFramework(frameworkId);
  7.   if (framework != NULL) {
  8.     // TODO(benh): Support offer "hoarding" and allow multiple offers
  9.     // *from the same slave* to be used to launch tasks. This can be
  10.     // accomplished rather easily by collecting and merging all offers
  11.     // into a mega-offer and passing that offer to
  12.     // Master::processTasks.
  13.     Offer* offer = getOffer(offerId);
  14.     if (offer != NULL) {
  15.       CHECK(offer->framework_id() == frameworkId);
  16.       Slave* slave = getSlave(offer->slave_id());
  17.       CHECK(slave != NULL) << "An offer should not outlive a slave!";
  18.       processTasks(offer, framework, slave, tasks, filters);
  19.     } else {
  20.       // The offer is gone (possibly rescinded, lost slave, re-reply
  21.       // to same offer, etc). Report all tasks in it as failed.
  22.       // TODO: Consider adding a new task state TASK_INVALID for
  23.       // situations like these.
  24.       LOG(WARNING) << "Offer " << offerId << " is no longer valid";
  25.       foreach (const TaskInfo& task, tasks) {
  26.         StatusUpdateMessage message;
  27.         StatusUpdate* update = message.mutable_update();
  28.         update->mutable_framework_id()->MergeFrom(frameworkId);
  29.         TaskStatus* status = update->mutable_status();
  30.         status->mutable_task_id()->MergeFrom(task.task_id());
  31.         status->set_state(TASK_LOST);
  32.         status->set_message("Task launched with invalid offer");
  33.         update->set_timestamp(Clock::now());
  34.         update->set_uuid(UUID::random().toBytes());
  35.         send(framework->pid, message);
  36.       }
  37.     }
  38.   }
  39. }
【1】根据frameworkId去master的hashmapframeworks中取出对应的framework对象,通过offerId获取了该offer的所有信息,调用了processTasks函数。
【2】该函数主要作用统计offer之中的资源使用情况,将其报告给allocator更新资源,调用了launchTask()我们下一节分析任务加载的过程。

总结一下:我们可以看到,其实在整个分配资源的过程之中,mesos用一些特定的数据结构,对于任务、资源、计算框架进行了逻辑上的标记、然后等逻辑上划分好了之后呢?然后再去通知真正的干事的程序去执行,这些逻辑上的数据结构跟实际的数据结构之间的对应关系设计的十分的巧妙,使得整个的调度变得十分的灵巧,减少了通讯的开销!

阅读(309) | 评论(0) | 转发(0) |
给主人留下些什么吧!~~