在前面2篇文章中,我们以启动协程基础API:startCoroutine{}入手,它是一个挂起函数类型的扩展函数,最终会让我们状态机Continuation对象多一个create()方法,从而创建状态机对象。
然后我们以launch{}入手,会发现其最终还是会调用createCoroutineUnintercepted来创建状态机Continuation对象,但是在这其中我们加入了很多关于协程的概念,比如Job、CoroutineScope等,这里能实现的原因非常简单,在协程构建器中,我们传入给挂起函数的Continuation对象,实现了Job等多个接口。
那本篇文章还是以launch{}入手,分析协程是如何进行线程调度的。
协程中关于线程调度的类就是Dispatchers了,我们可以使用withContext(Dispatchers.IO)或者其他方法来指定协程block所执行的线程,所以我们先来看看Dispatchers相关的内容。
Dispatchers调度器相关首先就是Dispatchers,它是一个单例类:
public actual object Dispatchers {
public actual val Default: CoroutineDispatcher = DefaultScheduler
public actual val Main: MainCoroutineDispatcher get() = MainDispatcherLoader.dispatcher
public actual val Unconfined: CoroutineDispatcher = kotlinx.coroutines.Unconfined
public val IO: CoroutineDispatcher = DefaultIoScheduler
}
这里可以发现我们平时用的几种调度器线程池:Default、Main、Unconfined和IO都是该单例的属性成员,同时他们的类型都是CoroutineDispatcher,即协程调度器。
这个协程调度器CoroutineDispatcher的继承关系如下:
public abstract class CoroutineDispatcher :
AbstractCoroutineContextElement(ContinuationInterceptor), ContinuationInterceptor {}
public interface ContinuationInterceptor : CoroutineContext.Element {}
public abstract class AbstractCoroutineContextElement(public override val key: Key<*>) : Element
这里的继承关系乍一看挺复杂的,我们来一一分析:
CoroutineDispatcher类,它是继承至抽象协程上下文Element类AbstractCoroutineContextElement,从命名来看,它就是Element的抽象类,提供了一些实现的公共方法。ContinuationInterceptor接口,这个接口也是Element的子接口,所以在代码第一行传递给AbstractCoroutineContextElement中的Key就是ContinuationInterceptor中的Key。Continuation合适的翻译,但是根据我们之前学习挂起函数原理的时候知道,Continuation是底层元素,在挂起函数经过CPS转换后,会得到一个状态机模型,那个模型就是Continuation子类SuspendLambda的对象。ContinuationInterceptor其实就是状态机的拦截器,我们可以对状态机对象进行拦截和处理。简单分析了上面几种关系,所以类的继承关系如下:

这个关系图在后面分析时有很大的作用。
Dispatchers.Default我们还是以简单的代码为例,比如下面代码:
fun main(){
testLaunch()
Thread.sleep(10000)
}
private fun testLaunch(){
val scope = CoroutineScope(Job())
scope.launch {
logX("Hello")
delay(1000)
logX("Kotlin")
}
}
/**
* 输出结果:
================================
Hello
Thread:DefaultDispatcher-worker-1 @coroutine#1
================================
================================
Kotlin
Thread:DefaultDispatcher-worker-1 @coroutine#1
================================
* */
在这里创建了一个CoroutineScope,但是并没有指定Dispatcher,我们从日志可以发现其执行的线程池为DefaultDispatcher,并且还可以打印出协程名字:@coroutine#1,这些是哪里帮我们完成的呢?
我们来看一下launch{}的源码:
public fun CoroutineScope.launch(
context: CoroutineContext = EmptyCoroutineContext,
start: CoroutineStart = CoroutineStart.DEFAULT,
block: suspend CoroutineScope.() -> Unit
): Job {
//注释1,获取新的上下文
val newContext = newCoroutineContext(context)
val coroutine = if (start.isLazy)
LazyStandaloneCoroutine(newContext, block) else
StandaloneCoroutine(newContext, active = true)
coroutine.start(start, coroutine, block)
return coroutine
}
这里的几行代码,我们又一次来分析了,这一次我们重点关注协程上下文。
EmptyCoroutineContext,在前面介绍CoroutineContext文章我们说过,CoroutineContext我们可以当成一个Map来使用,而这里的EmptyCoroutineContext就是一个空Map,也就等于没有传递;只不过Kotlin使用这个来代替null。context进行处理,newCoroutineContext()方法源码如下:public actual fun CoroutineScope.newCoroutineContext(context: CoroutineContext): CoroutineContext {
//注释1 继承父协程上下文
val combined = coroutineContext.foldCopiesForChildCoroutine() + context
//注释2 当是调试模式时,添加日志
val debug = if (DEBUG) combined + CoroutineId(COROUTINE_ID.incrementAndGet()) else combined
//注释3 添加Default
return if (combined !== Dispatchers.Default && combined[ContinuationInterceptor] == null)
debug + Dispatchers.Default else debug
}
上面代码我们来一一分析:
newCoroutineContext()方法是CoroutineScope的扩展函数,所以注释1的coroutineContext就是该CoroutineScope的coroutineContext成员属性对象,这个关系我们之前说过,CoroutineScope是对CoroutineContext的一层封装。foldCopiesChildCoroutine()函数作用就是将CoroutineScope当中的所有上下文元素都拷贝出来,然后跟传入的context进行合并。这行代码,可以让子协程继承父协程的上下文元素。@coroutine#1信息。combined不等于Dispatchers.Default时,或者combined[ContinuationInterceptor]为null时,给上下文添加Deispatchers.Default。Key是ContinuationInterceptor,且默认会设置为Dispatchers.Default。所以默认是Default线程池,因为Kotlin是支持多平台的,只有UI编程的平台比如Android才有Main主线程的概念,所以这里默认是Default一定不会错。
intercepted拦截分析既然我们知道了在哪里设置了协程的调度器,那在哪里切换线程以及在特定线程上执行协程呢?
还是回到我们熟悉的函数:
public fun <T> (suspend () -> T).startCoroutineCancellable(completion: Continuation<T>): Unit = runSafely(completion) {
createCoroutineUnintercepted(completion).intercepted().resumeCancellableWith(Result.success(Unit))
}
上面这个函数在之前文章已经分析很多遍了,至少我们知道createCoroutineUnintercepted(completion)就完成了协程的创建,或者说已经完成了协程Continuation状态机的创建。
那么核心的再处理就是这里的intercepted()方法了:
public actual fun <T> Continuation<T>.intercepted(): Continuation<T> =
(this as? ContinuationImpl)?.intercepted() ?: this
对Continuation进行拦截处理,这里代码很简单,把Continuation强转为ContinuationImpl,然后调用其intercepted()方法。
根据前面文章分析,我们知道这里的真正类型是SuspendLambda,它是ContinuationImapl的子类,所以这个转换一定能成功,我们接着来看intercepted()方法:
public fun intercepted(): Continuation<Any?> =
intercepted
?: (context[ContinuationInterceptor]?.interceptContinuation(this) ?: this)
.also { intercepted = it }
context中保存的ContinuationInterceptor,在前面分析中,我们可知这个context其实就是我们前面创建出来的协程上下文context。intercepted的值就会是我们前面所赋值的Dispatchers.Default。所以这里会调用Dispatchers.Default的interceptContinuation()方法,注意这里会将this即状态机自己传入到该函数中。
Dispatchers.Default分析这里我们视角又绕回了Dispatchers.Default,我们通过查看可以发现interceptContinuation方法是定义在ContinuationInterceptor接口中的抽象方法,其实现地方是CoroutineDispatcher抽象类,如下:
public final override fun <T> interceptContinuation(continuation: Continuation<T>): Continuation<T> =
DispatchedContinuation(this, continuation)
会发现这里会返回一个DispatchedContinuation实例对象,参数this就是Default,continuation就是状态机。
到这里我们为了逻辑更清晰、分层,可以把前面的startCoroutineCancellable()方法改写一下:
public fun <T> (suspend () -> T).startCoroutineCancellable(completion: Continuation<T>): Unit = runSafely(completion) {
createCoroutineUnintercepted(completion).intercepted().resumeCancellableWith(Result.success(Unit))
}
//改写如下
public fun <T> (suspend () -> T).startCoroutineCancellable(completion: Continuation<T>): Unit = runSafely(completion) {
// 1 创建出状态机Continuation对象
val continuation = createCoroutineUnintercepted(completion)
// 2 调用intercepted得到DispatchedContinuation对象
val dispatchedContinuation = continuation.intercepted()
// 3 进行后续处理
dispatchedContinuation.resumeCancellableWith(Result.success(Unit))
}
所以我们分析的重点就来到了这个DispatchedContinuation类。
在分析该类之前,我们来看一下Dispatchers.Default的具体继承关系:
//类型是CoroutineDispatcher,实现是DefaultScheduler
public actual val Default: CoroutineDispatcher = DefaultScheduler
//单例,继承至SchedulerCoroutineDispatcher
internal object DefaultScheduler : SchedulerCoroutineDispatcher
//继承至ExecutorCoroutineDispatcher
internal open class SchedulerCoroutineDispatcher(
private val corePoolSize: Int = CORE_POOL_SIZE,
private val maxPoolSize: Int = MAX_POOL_SIZE,
private val idleWorkerKeepAliveNs: Long = IDLE_WORKER_KEEP_ALIVE_NS,
private val schedulerName: String = "CoroutineScheduler",
) : ExecutorCoroutineDispatcher()
//继承至CoroutineDispatcher
public abstract class ExecutorCoroutineDispatcher: CoroutineDispatcher()
可以发现最终继承至CoroutineDispatcher抽象类,关于该类的关系,在前面我们分析过了。
DispatchedContinuation类分析先来看一下这个DispatchedContinuation类的定义:
internal class DispatchedContinuation<in T>(
@JvmField val dispatcher: CoroutineDispatcher,
@JvmField val continuation: Continuation<T>
) : DispatchedTask<T>(MODE_UNINITIALIZED), CoroutineStackFrame, Continuation<T> by continuation {}
会发现这个类的定义还是非常复杂的,首先它实现了Continuation接口,但是使用了类委托,把接口实现都委托给了传递进来的continuation参数。其次参数dispatcher就是前面分析的默认参数Dispatchers.Default,continuation就是block协程实现类,具体类型是SuspendLambda。
然后发现这个类还继承至DispatchedTask,我们来看一下这个类:
internal abstract class DispatchedTask<in T>(
@JvmField public var resumeMode: Int
) : SchedulerTask() {}
internal actual typealias SchedulerTask = Task
internal abstract class Task(
@JvmField var submissionTime: Long,
@JvmField var taskContext: TaskContext
) : Runnable{}
这里会发现DispatchedTask继承至SchedulerTask,该类继承至Task,而Task则继承至我们非常熟悉的Runnable接口,这也就意味着它可以被分到Java的线程当中去执行了。
resumeCancellableWith()分析既然它是Runnable,我们就来看看如何进行分配,来看看resumeCancellableWith()的代码实现:
//DispatchedContinuation类
inline fun resumeCancellableWith(
result: Result<T>,
noinline onCancellation: ((cause: Throwable) -> Unit)?
) {
val state = result.toState(onCancellation)
//注释1
if (dispatcher.isDispatchNeeded(context)) {
_state = state
resumeMode = MODE_CANCELLABLE
//注释2
dispatcher.dispatch(context, this)
} else {
//注释3
executeUnconfined(state, MODE_CANCELLABLE) {
if (!resumeCancelled(state)) {
resumeUndispatchedWith(result)
}
}
}
}
isDispatchNeeded的意思是是否需要分发,这里只有当是Dispatchers.Unconfined时,才返回false,所以本例中代码是Dispatchers.Default,所以会进入注释2的逻辑。this(实现了Runnable接口)传递。Dispatcher.Unconfined的情况下,这里会直接在当前线程执行。这里调用的是dispatcher.dispatch(),其实我们知道,就是Dispatchers.Default.dispatch()方法,下面是我们回到Dispatchers.Default的源码:
public actual val Default: CoroutineDispatcher = DefaultScheduler
internal object DefaultScheduler : SchedulerCoroutineDispatcher(
CORE_POOL_SIZE, MAX_POOL_SIZE,
IDLE_WORKER_KEEP_ALIVE_NS, DEFAULT_SCHEDULER_NAME
) {}
DefaultScheduler则是一个单例,继承至SchedulerCoroutineDispatcher,
internal open class SchedulerCoroutineDispatcher(
private val corePoolSize: Int = CORE_POOL_SIZE,
private val maxPoolSize: Int = MAX_POOL_SIZE,
private val idleWorkerKeepAliveNs: Long = IDLE_WORKER_KEEP_ALIVE_NS,
private val schedulerName: String = "CoroutineScheduler",
) : ExecutorCoroutineDispatcher() {
private fun createScheduler() =
CoroutineScheduler(corePoolSize, maxPoolSize, idleWorkerKeepAliveNs, schedulerName)
//这就是前面调用的dispatch方法
override fun dispatch(context: CoroutineContext, block: Runnable): Unit = coroutineScheduler.dispatch(block)
}
而这里我们发现dispatch方法中会调用CoroutineScheduler中的dispatch()方法:
internal class CoroutineScheduler(
@JvmField val corePoolSize: Int,
@JvmField val maxPoolSize: Int,
@JvmField val idleWorkerKeepAliveNs: Long = IDLE_WORKER_KEEP_ALIVE_NS,
@JvmField val schedulerName: String = DEFAULT_SCHEDULER_NAME
) : Executor, Closeable {
override fun execute(command: Runnable) = dispatch(command)
//核心方法
fun dispatch(block: Runnable, taskContext: TaskContext = NonBlockingContext, tailDispatch: Boolean = false) {
trackTask()
// 1
val task = createTask(block, taskContext)
// 2
val currentWorker = currentWorker()
// 3
val notAdded = currentWorker.submitToLocalQueue(task, tailDispatch)
if (notAdded != null) {
if (!addToGlobalQueue(notAdded)) {
throw RejectedExecutionException("$schedulerName was terminated")
}
}
val skipUnpark = tailDispatch && currentWorker != null
if (task.mode == TASK_NON_BLOCKING) {
if (skipUnpark) return
signalCpuWork()
} else {
signalBlockingWork(skipUnpark = skipUnpark)
}
}
private fun currentWorker(): Worker? = (Thread.currentThread() as? Worker)?.takeIf { it.scheduler == this }
// 内部类 Worker
internal inner class Worker private constructor() : Thread() {
}
}
这里我们发现CoroutineScheduler其实就是Java并发包Executor的子类,它的execute方法也被转到了dispatch方法,所以终于到了Java线程处理部分了,上面代码有3个注释:
Runnable类型的block,其实也就是DispatchedContinuation,包装成Task。currentWorker()就是拿到当前执行的线程,这里的Worker是一个内部类,它的本质是Java的Thread。currentWorker.submitToLocalQueue(),将当前的Task添加到Worker线程的本地队列中,等待执行。这里我们来分析一下Worker是如何执行Task的。下面是Worker代码,代码较多,只列出有用信息:
internal inner class Worker private constructor() : Thread() {
//重写了Thread的run方法
override fun run() = runWorker()
@JvmField
var mayHaveLocalTasks = false
private fun runWorker() {
var rescanned = false
while (!isTerminated && state != WorkerState.TERMINATED) {
// 1 找到task
val task = findTask(mayHaveLocalTasks)
if (task != null) {
rescanned = false
minDelayUntilStealableTaskNs = 0L
// 2 执行task
executeTask(task)
continue
} else {
mayHaveLocalTasks = false
}
if (minDelayUntilStealableTaskNs != 0L) {
if (!rescanned) {
rescanned = true
} else {
rescanned = false
tryReleaseCpu(WorkerState.PARKING)
interrupted()
LockSupport.parkNanos(minDelayUntilStealableTaskNs)
minDelayUntilStealableTaskNs = 0L
}
continue
}
tryPark()
}
tryReleaseCpu(WorkerState.TERMINATED)
}
}
这里Worker会重写Thread的run()方法,然后把执行流程交由给runWorkder(),这里代码注意2点:
while循环中,一直尝试从Worker的本地队列中取出Task。executeTask方法,来执行其对应的Task。接下来就是关键的执行Task代码:
internal inner class Worker private constructor() : Thread() {
private fun executeTask(task: Task) {
val taskMode = task.mode
idleReset(taskMode)
beforeTask(taskMode)
// 1 执行task
runSafely(task)
afterTask(taskMode)
}
}
fun runSafely(task: Task) {
try {
// 2 调用run方法
task.run()
} catch (e: Throwable) {
val thread = Thread.currentThread()
thread.uncaughtExceptionHandler.uncaughtException(thread, e)
} finally {
unTrackTask()
}
}
internal abstract class Task(
@JvmField var submissionTime: Long,
@JvmField var taskContext: TaskContext
) : Runnable {
constructor() : this(0, NonBlockingContext)
inline val mode: Int get() = taskContext.taskMode // TASK_XXX
}
这里我们调用runSafely方法,然后在这个方法中我们执行了task.run(),而Task的本质是Runnable,到目前就代表了我们的协程任务真正执行了。
注意又回到前面了,这里的run执行的具体逻辑是啥,从前面类的继承关系来看,这里执行的是DispatchedTask.run()方法,而这个类实际上是DispatchedContinuation的子类,所以会调用下面代码:
internal class DispatchedContinuation<in T>(
@JvmField val dispatcher: CoroutineDispatcher,
@JvmField val continuation: Continuation<T>
) : DispatchedTask<T>(MODE_UNINITIALIZED), CoroutineStackFrame, Continuation<T> by continuation {
//会回调该方法
public final override fun run() {
val taskContext = this.taskContext
var fatalException: Throwable? = null
try {
val delegate = delegate as DispatchedContinuation<T>
val continuation = delegate.continuation
withContinuationContext(continuation, delegate.countOrElement) {
val context = continuation.context
val state = takeState()
val exception = getExceptionalResult(state)
val job = if (exception == null && resumeMode.isCancellableMode) context[Job] else null
if (job != null && !job.isActive) {
// 1
val cause = job.getCancellationException()
cancelCompletedResult(state, cause)
continuation.resumeWithStackTrace(cause)
} else {
if (exception != null) {
// 2
continuation.resumeWithException(exception)
} else {
// 3
continuation.resume(getSuccessfulResult(state))
}
}
}
} catch (e: Throwable) {
fatalException = e
} finally {
val result = runCatching { taskContext.afterTask() }
handleFatalException(fatalException, result.exceptionOrNull())
}
}
}
上面代码主要就看3个注释点:
resumeWithStackTrace把具体原因传出去。resumeWithException将异常传递出去。resume启动协程,并且执行launch中传入的lambda表达式。到这里,我们就完全分析完了整个流程。
本篇文章分析了launch的流程,而其中与线程交互重点就是Dispatchers,主要有下面几个步骤:
createCoroutineUnintercepted(completion)创建了协程的Continuation实例,接着调用intercepted()方法,将其封装为DispatchedContinuation对象。DispatchedContinuation会持有CoroutineDispatcher、以及前面创建的Continuation对象,比如文中的CoroutineDispatcher就是Default线程池。DispatchedContinuation的resumeCancellableWith()方法,会执行dispatcher.dispatch()方法,这个会将Continuation封装为Task,添加到线程中去执行。在这一步,协程就已经完成了线程切换。run方法会调用DispatchedContinuation的run方法,会调用continuation.resume方法,它将执行原本launch当中生成的SuspendLambda子类,这时候协程的代码就在线程上执行了。分析完会发现,协程框架设计是非常巧妙的,将线程池信息保存在协程上下文中,把创建完的协程SuspendLambda实例实现Runnable接口,然后封装为Task,在指定线程池中运行,从而完成线程切换。
阅读量:256
点赞量:0
收藏量:0