通过模板类简单实现Spark的JobServer
实验前后效果对比:
之前:执行13个节点,耗时16分钟
之后:同样13个节点,耗时3分钟
具体逻辑请参照代码及注释。
- import java.util.concurrent.{ExecutorService, Executors, TimeUnit}
- import akka.actor.{ActorSystem, Props}
- import com.alibaba.fastjson.JSONObject
- import xxx.listener.AddJobToQueueActor
- import xxx.listener.bean.{AppStatusMessage, SparkContextStatusMessage}
- import xxx.listener.utils.JSONUtil
- import xxx.listener.utils.JmsUtils._
- import xxx.main.SparkJob
- import xxx.main.utils.JsonUtils
- import com.typesafe.config.ConfigFactory
- import org.apache.commons.lang.StringUtils
- import org.apache.spark.sql.hive.HiveContext
- import org.apache.spark.{Logging, SparkConf, SparkContext}
- import scala.collection.mutable.Queue
- /**
- * Created by zpc on 2016/9/1.
- * JobServer实现模板。
- * 修正前:各个任务节点独立提交到spark平台,其中启动sparkContext和hiveContext会占用大量时间,大约40多秒。
- * 修改后:将统一用户,占用资源相同的节点利用JMS发送消息提交到同一个SparkContext上,默认设置为3个节点任务并行。
- * 实现:1.提交到queue中的msg为任务包含任务中型的子类及参数信息,接收到的任务不存在依赖关系,依赖的处理在消息发送端控制。
- * 前置任务执行结束,再发送下一节点任务。
- * 2.第一次提交时,任务的参数在args中获取。启动之后,启动jms的lister监听,通过actor将接收到的任务信息加入队列。
- * 3.通过反射调用SparkJob的各个子类(真正执行节点逻辑的类),SparkContext的默认timeout时间为30mins。
- * 4.节点执行结束,发送节点成功消息到web端,节点失败,发送错误日志及错误消息。
- * 程序退出,通过shutdownhook,发送sc关闭消息到web端。
- * 程序被关闭,如kill时,将等待队列及正在执行集合中的任务,发送失败消息到web端。
- *
- *
- */
- object ExecuteJobServer extends Logging {
- //等待执行的job所在的queue
- val jobWaitingQueue = new Queue[String]
- //当前正在执行的任务的集合
- val jobRunningSet = new scala.collection.mutable.HashSet[JSONObject]
- val timeout_mins = 30
- //最后运行任务时间
- var lastRunTime = System.currentTimeMillis()
- //spark context 对应的 applicationId, user, expId, resource
- var appId : String = ""
- var user: String = ""
- var expId: Long = 0
- var resource: String = ""
- //正在执行的job JSON
- var jobJson : JSONObject = null
- def main(args: Array[String]): Unit = {
- //进程杀死时,将正在执行或未执行的任务,发送失败消息到web端。
- Runtime.getRuntime().addShutdownHook(new HookMessage())
- //接收到的任务,可以同时提交时,线程数可以多设置,暂定为3
- val threadPool: ExecutorService = Executors.newFixedThreadPool(3)
- val sc = initSparkContext()
- val hiveContext = new HiveContext(sc)
- val list = JsonUtils.parseArray(args(0))
- val it = list.iterator
- while (it.hasNext) {
- val jobStr = it.next().toString
- if(expId == 0){
- val json = JSONUtil.toJSONString(jobStr)
- val param = json.getJSONObject("params")
- appId = sc.applicationId
- user = param.getString("user")
- expId = param.getLongValue("expId")
- var driver_memory = ""
- var num_executors = "spark.executor.instances"
- var executor_memory = ""
- sc.getConf.getAll.map( x => {
- if(x._1 != null && "spark.executor.instances".equals(x._1)) {
- num_executors = x._2
- }
- else if(x._1 != null && "spark.executor.memory".equals(x._1)){
- executor_memory = x._2.substring(0, x._2.length - 1)
- }else if(x._1 != null && "spark.driver.memory".equals(x._1)){
- driver_memory = x._2.substring(0, x._2.length - 1)
- }
- })
- resource = driver_memory + num_executors + executor_memory;
- logInfo("resource is : " +resource)
- // resource = param.getString("driver-memory") + param.getString("num-executors") + param.getString("executor-memory")
- }
- jobWaitingQueue.enqueue(jobStr)
- }
- /** 1.启动listener监听appId,接收queue中发送过来的JobMsg消息2.通过Queue发送消息通知web端,sc启动 **/
- val system = ActorSystem("mlp", ConfigFactory.load())
- val actor = system.actorOf(Props(new AddJobToQueueActor(appId, jobWaitingQueue)))
- createTopicListenerOfContextJobMsg("contextJobMsgListener", actor)
- informSparkContextStatus(true)
- while (jobWaitingQueue.size > 0 || !checkTimeOut) {
- while (jobWaitingQueue.size > 0) {
- lastRunTime = System.currentTimeMillis()
- val jobStr = jobWaitingQueue.dequeue()//.replace("\\", "")
- logInfo("***** ExecuteJobServer jobStr ***** jobStr: " + jobStr)
- val json = JSONUtil.toJSONString(jobStr)
- jobRunningSet.add(json)
- threadPool.execute(new ThreadSparkJob(json, hiveContext, sc))
- jobJson = json
- }
- Thread.sleep(1000)
- }
- /**
- * jobWaittingQueue队列不再接收消息
- *
- */
- threadPool.shutdown()
- var loop = true
- do {
- //等待所有任务完成
- loop = !threadPool.awaitTermination(2, TimeUnit.SECONDS); //阻塞,直到线程池里所有任务结束
- } while (loop);
- }
- def checkTimeOut(): Boolean = {
- val nowTime = System.currentTimeMillis()
- if (jobRunningSet.isEmpty && (nowTime - lastRunTime) / (1000 * 60) > timeout_mins) {
- return true
- } else {
- return false
- }
- }
- class ThreadSparkJob(json: JSONObject, hiveContext: HiveContext, ctx: SparkContext) extends Runnable {
- override def run() {
- try{
- val classStr = json.get("class").toString
- val argsStr = json.get("params").toString
- val obj: SparkJob = Class.forName(classStr).getMethod("self").invoke(null).asInstanceOf[SparkJob]
- // val obj: SparkJob = Class.forName(classStr).newInstance().asInstanceOf[SparkJob]
- obj.jobServer = true
- obj.failed = false
- obj.setContext(ctx)
- obj.setHiveContext(hiveContext)
- obj.main(Array(argsStr))
- // InformJobSuccess(json)
- logInfo("***** jobRunningSet remove job json***** json: " + json.toJSONString )
- jobRunningSet.remove(json)
- lastRunTime = System.currentTimeMillis()
- }catch {
- case oom: OutOfMemoryError => {
- informJobFailure(oom.toString, json)
- jobRunningSet.remove(json)
- logInfo("***** SparkContext go to stop, reaseon: " + oom.getMessage )
- hiveContext.sparkContext.stop()
- //异常时,sc停止,driver程序停止
- System.exit(1)
- }
- case ex: Exception => {
- informJobFailure(ex.toString, json)
- jobRunningSet.remove(json)
- if(ex.toString.contains("stopped SparkContext")){
- logInfo("***** SparkContext go to stop, reaseon: " + ex.getMessage )
- hiveContext.sparkContext.stop()
- //异常时,sc停止,driver程序停止
- System.exit(1)
- }
- }
- }
- }
- def informJobFailure(errMsg: String, json: JSONObject) = {
- if(json != null) {
- val params = json.getJSONObject("params")
- val user = StringUtils.trimToEmpty(params.getString("user"))
- val expId = params.getLongValue("expId")
- val nodeId = params.getLongValue("nodeId")
- val message = new AppStatusMessage(user, expId, nodeId, "FAILURE", errMsg)
- logInfo("***** send informJobFailure message*****: expId: " + expId + "nodeId: " + nodeId)
- jobStatusTemplate send message
- }
- }
- }
- def initSparkContext(): SparkContext = {
- val conf = new SparkConf().setAppName("cbt-mlaas")
- new SparkContext(conf)
- }
- class HookMessage extends Thread {
- override def run() {
- var shouldInformStop = false
- informSparkContextStatus(false)
- while (jobWaitingQueue.size > 0) {
- val jobStr = jobWaitingQueue.dequeue()//.replace("\\", "")
- val json = JSONUtil.toJSONString(jobStr)
- informJobFailureInHook("SparkContext stopped, inform waiting job failed!", json)
- shouldInformStop = true
- }
- jobRunningSet.map(json => {
- informJobFailureInHook("SparkContext stopped, inform running job failed!", json);
- shouldInformStop = true
- })
- if (shouldInformStop) {
- informExpStop("SparkContext stopped, inform exp failed!", jobJson)
- }
- }
- def informJobFailureInHook(errMsg: String, json: JSONObject) = {
- if(json != null) {
- val params = json.getJSONObject("params")
- val user = StringUtils.trimToEmpty(params.getString("user"))
- val expId = params.getLongValue("expId")
- val nodeId = params.getLongValue("nodeId")
- val message = new AppStatusMessage(user, expId, nodeId, "FAILURE", errMsg)
- logInfo("***** send informJobFailure message*****: expId: " + expId + "nodeId: " + nodeId)
- jobStatusTemplate send message
- }
- }
- def informExpStop(errMsg: String, json: JSONObject) = {
- if(json != null) {
- val params = json.getJSONObject("params")
- val user = StringUtils.trimToEmpty(params.getString("user"))
- val expId = params.getLongValue("expId")
- val nodeId = params.getLongValue("nodeId")
- val message = new AppStatusMessage(user, expId, nodeId, "STOP", errMsg)
- logInfo("***** send informExpStop message*****: expId: " + expId + "nodeId: " + nodeId)
- jobStatusTemplate send message
- }
- }
- }
- def informSparkContextStatus(start : Boolean) = {
- val msg = new SparkContextStatusMessage(appId, start, user, expId, resource)
- logInfo("***** send sparkContext start message*****: appId: " + appId + "start: " + start)
- sparkContextStatusTemplate send msg
- }
- }
通过模板类简单实现Spark的JobServer的更多相关文章
- [转贴]从零开始学C++之STL(二):实现一个简单容器模板类Vec(模仿VC6.0 中 vector 的实现、vector 的容量capacity 增长问题)
首先,vector 在VC 2008 中的实现比较复杂,虽然vector 的声明跟VC6.0 是一致的,如下: C++ Code 1 2 template < class _Ty, cl ...
- [置顶] 从零开始学C++之STL(二):实现简单容器模板类Vec(vector capacity 增长问题、allocator 内存分配器)
首先,vector 在VC 2008 中的实现比较复杂,虽然vector 的声明跟VC6.0 是一致的,如下: C++ Code 1 2 template < class _Ty, ...
- 实现简单容器模板类Vec(vector capacity 增长问题、allocator 内存分配器)
首先,vector 在VC 2008 中的实现比较复杂,虽然vector 的声明跟VC6.0 是一致的,如下: C++ Code 1 2 template < class _Ty, cl ...
- C++入门经典-例9.3-类模板,简单类模板
1:使用template关键字不但可以定义函数模板,而且可以定义类模板.类模板代表一族类,它是用来描述通用数据类型或处理方法的机制,它使类中的一些数据成员和成员函数的参数或返回值可以取任意数据类型.类 ...
- 类的编写模板之简单Java类
简单Java类是初学java时的一个重要的类模型,一般由属性和getter.setter方法组成,该类不涉及复杂的逻辑运算,仅仅是作为数据的储存,同时该类一般都有明确的实物类型.如:定义一个雇员的类, ...
- c++模板类
c++模板类 理解编译器的编译模板过程 如何组织编写模板程序 前言常遇到询问使用模板到底是否容易的问题,我的回答是:“模板的使用是容易的,但组织编写却不容易”.看看我们几乎每天都能遇到的模板类吧,如S ...
- C++模板类的使用
1.定义模板类 通过类似于下面的语法可以定义一个模板类: template<typename T> class Job : public virtual RefBase { public: ...
- C++模板编程里的主版本模板类、全特化、偏特化(C++ Type Traits)
1. 主版本模板类 首先我们来看一段初学者都能看懂,应用了模板的程序: 1 #include <iostream> 2 using namespace std; 3 4 template ...
- C++中的链表节点用模板类和用普通类来实现的区别
C++中的链表节点通常情况下类型都是一致的.因此我们可以用模板来实现. #include <iostream> using namespace std; template<typen ...
随机推荐
- java oop
/** 多层嵌套内部类, 调用时要层层往下调用 格式: 外部类.内部类1.内部类2 对象名 = new 外部类().new 内部类1().new 内部类2(); 对象名.属性/方法名(); */ cl ...
- .Net 中资源的使用方式
近期要在小丸工具箱中添加一个启动画面,画面中需要使用一个GIF动图.经过学习和实验,总结了几个读取资源的方式,罗列如下. 一.使用外部资源 Image img = Image.FromFile(&qu ...
- php 开启缓冲,页面纯静态化
服务器默认不开启php缓冲区 两种方法开启 1.php.ini out_put_buffer = on 2.ob_start(); 页面纯静态化 file_put_contents()写文件 ob_s ...
- PHP学习心得(四)——基本语法
从 HTML 中分离 当 PHP 解析一个文件时,会寻找开始和结束标记,标记告诉 PHP 开始和停止解释其中的代码.此种方式的解析可以使 PHP 嵌入到各种不同的文档中,凡是在一对开始和结束标记之外的 ...
- CentOS 根据命令查所在的包
在工作中经常会遇到想用某个命令机器没装却又不知道命令在哪个包(源码编译不再本文范围内),下面介绍个比较笨的方法可以帮助我们搞定这个问题. 说明:蓝色=命令名称 浅绿=命令参数 ...
- nuget的使用总结
使用NuGet发布自己的类库包(Library Package) from:http://blog.csdn.net/gulijiang2008/article/details/41724927 使用 ...
- Ubuntu 下部署asp.net运行环境
在Ubuntu下部署asp.net运行环境,网上教程很多,基本都是编译Mono源码,然后安装jexus.但是可能是我最近RP不太好,编译Mono源码一直都是失败,无奈之下只好找另外的方法安装了. 网上 ...
- sharepoint 2013 sp1
http://www.microsoft.com/en-us/download/details.aspx?id=42544 http://soussi-imed.over-blog.com/artic ...
- windows azure programing
http://azure.microsoft.com/en-us/documentation/articles/web-sites-dotnet-get-started-vs2012/ http:// ...
- javascript高级编程笔记03(正则表达式)
引用类型 检测数组 注:我们实际开发中经常遇到要把数组转化成以逗号隔开,我以前都是join来实现,其实又更简单的方法可以用toString方法,它会自动用逗号隔开转换成字符串,其实toString内部 ...