通过模板类简单实现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 ...
随机推荐
- RSA使用 常识
1公钥加密,私钥解密 OK反过来, 私钥加密,公钥解密 也OK 2 使用RSA加密 对称算法的key ,用对称算法加密 消息.伙伴收到消息后,RSA解密出 对称算法的key,再用这个key去解密消息 ...
- python 列表推导的注意点
Code a = [1,2,2,3] b = [for item in a if item not in b] c = [] for item in a: if item not in c: c.ap ...
- Pycharm使用技巧
1.代码配色,即主题 pycharm自带的配色方案都很难看,网上的配色方案又很难看,所以根据其他ide的Monokai配色方案,自己定义了一个. pycharm Monokai主题下载:http:// ...
- [转载]C#读取Excel几种方法的体会
C#读取Excel几种方法的体会 转载地址:http://developer.51cto.com/art/201302/380622.htm (1) OleDb: 用这种方法读取Excel速度还是非常 ...
- LCA——倍增求解
LCA,即最近公共祖先,用于解决树上两点的最近公共祖先问题. ; lca(1,2)=3;(原谅我的绘画水平) LCA的求解有三种算法(我知道的)——tarjan,倍增,线段树(我只会两种),NOIp之 ...
- python 文件查找 glob
glob模块是最简单的模块之一,内容非常少.用它可以查找符合特定规则的文件路径名.跟使用windows下的文件搜索差不多.查找文件只用到三个匹配符:"*", "?&quo ...
- js 字符串扩展
<script type="text/javascript" language="javascript"> String.prototype.tri ...
- ExtJS4.2学习(14)基于表格的扩展插件(2)(转)
鸣谢:http://www.shuyangyang.com.cn/jishuliangongfang/qianduanjishu/2013-11-26/184.html --------------- ...
- html5判断用户摇晃了手机(转)
先来看下html5的这几个特性: 1.deviceOrientation:方向传感器数据的事件,通过监听该事件可以获取手机静态状态下的方向数据: 2.deviceMotion: 运动传感器数据事件,通 ...
- vs2012+cmake+opencv+opencv unable to find a build program corresponding to "Visual Studio 12 Win64". CMAKE_MAKE_PROGRAM is not set
搜索了下,说什么的都有! 一,提示找不到 cmake-2.8.12.1 的 modles 卸载了cmake后发现 cmd 中的 cmake --version 还是 2.8.11.1 找到是我的cyg ...