Replace RxJava in DownloadQueue (#9016)
* Misc cleanup - Replace !List.isEmpty with List.isNotEmpty - Remove redundant case in MoreScreenModel - Drop no-op StateFlow.catch - From lint warning: > SharedFlow never completes, so this operator typically has not > effect, it can only catch exceptions from 'onSubscribe' operator * Convert DownloadQueue queue to MutableStateFlow Replace delegation to a MutableList with an internal MutableStateFlow<List>. In order to avoid modifying every usage of the queue as a list, add passthrough functions for the currently used list functions. This should be later refactored, possibly by inlining DownloadQueue into Downloader. DownloadQueue.updates was a SharedFlow which updated every time a change was made to the queue. This is now equivalent to the queue StateFlow. Simultaneous assignments to _state.value could cause concurrency issues. To avoid this, always modify the queue using _state.update. * Add Download.statusFlow/progressFlow progressFlow is based on the DownloadQueueScreenModel implementation rather than the DownloadQueue implementation. * Reimplement DownloadQueue.statusFlow/progressFlow Use StateFlow<List<T>>.flatMapLatest() and List<Flow<T>>.merge() to replicate the effect of PublishSubject. Use drop(1) to avoid re-emitting the state of each download each time the merged flow is recreated. * fixup! Reimplement DownloadQueue.statusFlow/progressFlow
This commit is contained in:
parent
0d8f1c8560
commit
bd2cb97179
@ -148,7 +148,7 @@ class Downloader(
|
|||||||
return
|
return
|
||||||
}
|
}
|
||||||
|
|
||||||
if (notifier.paused && !queue.isEmpty()) {
|
if (notifier.paused && queue.isNotEmpty()) {
|
||||||
notifier.onPaused()
|
notifier.onPaused()
|
||||||
} else {
|
} else {
|
||||||
notifier.onComplete()
|
notifier.onComplete()
|
||||||
|
@ -5,7 +5,14 @@ import eu.kanade.domain.manga.interactor.GetManga
|
|||||||
import eu.kanade.tachiyomi.source.SourceManager
|
import eu.kanade.tachiyomi.source.SourceManager
|
||||||
import eu.kanade.tachiyomi.source.model.Page
|
import eu.kanade.tachiyomi.source.model.Page
|
||||||
import eu.kanade.tachiyomi.source.online.HttpSource
|
import eu.kanade.tachiyomi.source.online.HttpSource
|
||||||
import rx.subjects.PublishSubject
|
import kotlinx.coroutines.delay
|
||||||
|
import kotlinx.coroutines.flow.MutableStateFlow
|
||||||
|
import kotlinx.coroutines.flow.asStateFlow
|
||||||
|
import kotlinx.coroutines.flow.combine
|
||||||
|
import kotlinx.coroutines.flow.debounce
|
||||||
|
import kotlinx.coroutines.flow.distinctUntilChanged
|
||||||
|
import kotlinx.coroutines.flow.emitAll
|
||||||
|
import kotlinx.coroutines.flow.flow
|
||||||
import tachiyomi.domain.chapter.model.Chapter
|
import tachiyomi.domain.chapter.model.Chapter
|
||||||
import tachiyomi.domain.manga.model.Manga
|
import tachiyomi.domain.manga.model.Manga
|
||||||
import uy.kohesive.injekt.Injekt
|
import uy.kohesive.injekt.Injekt
|
||||||
@ -25,20 +32,31 @@ data class Download(
|
|||||||
@Transient
|
@Transient
|
||||||
var downloadedImages: Int = 0
|
var downloadedImages: Int = 0
|
||||||
|
|
||||||
@Volatile
|
|
||||||
@Transient
|
@Transient
|
||||||
var status: State = State.NOT_DOWNLOADED
|
private val _statusFlow = MutableStateFlow(State.NOT_DOWNLOADED)
|
||||||
|
|
||||||
|
@Transient
|
||||||
|
val statusFlow = _statusFlow.asStateFlow()
|
||||||
|
var status: State
|
||||||
|
get() = _statusFlow.value
|
||||||
set(status) {
|
set(status) {
|
||||||
field = status
|
_statusFlow.value = status
|
||||||
statusSubject?.onNext(this)
|
|
||||||
statusCallback?.invoke(this)
|
|
||||||
}
|
}
|
||||||
|
|
||||||
@Transient
|
@Transient
|
||||||
var statusSubject: PublishSubject<Download>? = null
|
val progressFlow = flow {
|
||||||
|
if (pages == null) {
|
||||||
|
emit(0)
|
||||||
|
while (pages == null) {
|
||||||
|
delay(50)
|
||||||
|
}
|
||||||
|
}
|
||||||
|
|
||||||
@Transient
|
val progressFlows = pages!!.map(Page::progressFlow)
|
||||||
var statusCallback: ((Download) -> Unit)? = null
|
emitAll(combine(progressFlows) { it.average().toInt() })
|
||||||
|
}
|
||||||
|
.distinctUntilChanged()
|
||||||
|
.debounce(50)
|
||||||
|
|
||||||
val progress: Int
|
val progress: Int
|
||||||
get() {
|
get() {
|
||||||
|
@ -1,69 +1,48 @@
|
|||||||
package eu.kanade.tachiyomi.data.download.model
|
package eu.kanade.tachiyomi.data.download.model
|
||||||
|
|
||||||
import eu.kanade.core.util.asFlow
|
|
||||||
import eu.kanade.tachiyomi.data.download.DownloadStore
|
import eu.kanade.tachiyomi.data.download.DownloadStore
|
||||||
import eu.kanade.tachiyomi.source.model.Page
|
|
||||||
import kotlinx.coroutines.CoroutineScope
|
|
||||||
import kotlinx.coroutines.Dispatchers
|
|
||||||
import kotlinx.coroutines.channels.Channel
|
|
||||||
import kotlinx.coroutines.flow.Flow
|
import kotlinx.coroutines.flow.Flow
|
||||||
import kotlinx.coroutines.flow.SharingStarted
|
import kotlinx.coroutines.flow.MutableStateFlow
|
||||||
|
import kotlinx.coroutines.flow.asFlow
|
||||||
|
import kotlinx.coroutines.flow.asStateFlow
|
||||||
|
import kotlinx.coroutines.flow.drop
|
||||||
|
import kotlinx.coroutines.flow.emitAll
|
||||||
|
import kotlinx.coroutines.flow.flatMapLatest
|
||||||
import kotlinx.coroutines.flow.map
|
import kotlinx.coroutines.flow.map
|
||||||
|
import kotlinx.coroutines.flow.merge
|
||||||
import kotlinx.coroutines.flow.onStart
|
import kotlinx.coroutines.flow.onStart
|
||||||
import kotlinx.coroutines.flow.receiveAsFlow
|
import kotlinx.coroutines.flow.update
|
||||||
import kotlinx.coroutines.flow.shareIn
|
|
||||||
import rx.Observable
|
|
||||||
import rx.subjects.PublishSubject
|
|
||||||
import tachiyomi.core.util.lang.launchNonCancellable
|
|
||||||
import tachiyomi.domain.chapter.model.Chapter
|
import tachiyomi.domain.chapter.model.Chapter
|
||||||
import tachiyomi.domain.manga.model.Manga
|
import tachiyomi.domain.manga.model.Manga
|
||||||
import java.util.concurrent.CopyOnWriteArrayList
|
|
||||||
|
|
||||||
class DownloadQueue(
|
class DownloadQueue(
|
||||||
private val store: DownloadStore,
|
private val store: DownloadStore,
|
||||||
private val queue: MutableList<Download> = CopyOnWriteArrayList(),
|
) {
|
||||||
) : List<Download> by queue {
|
private val _state = MutableStateFlow<List<Download>>(emptyList())
|
||||||
|
val state = _state.asStateFlow()
|
||||||
private val scope = CoroutineScope(Dispatchers.IO)
|
|
||||||
|
|
||||||
private val statusSubject = PublishSubject.create<Download>()
|
|
||||||
|
|
||||||
private val _updates: Channel<Unit> = Channel(Channel.UNLIMITED)
|
|
||||||
val updates = _updates.receiveAsFlow()
|
|
||||||
.onStart { emit(Unit) }
|
|
||||||
.map { queue }
|
|
||||||
.shareIn(scope, SharingStarted.Eagerly, 1)
|
|
||||||
|
|
||||||
fun addAll(downloads: List<Download>) {
|
fun addAll(downloads: List<Download>) {
|
||||||
|
_state.update {
|
||||||
downloads.forEach { download ->
|
downloads.forEach { download ->
|
||||||
download.statusSubject = statusSubject
|
|
||||||
download.statusCallback = ::setPagesFor
|
|
||||||
download.status = Download.State.QUEUE
|
download.status = Download.State.QUEUE
|
||||||
}
|
}
|
||||||
queue.addAll(downloads)
|
|
||||||
store.addAll(downloads)
|
store.addAll(downloads)
|
||||||
scope.launchNonCancellable {
|
it + downloads
|
||||||
_updates.send(Unit)
|
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
fun remove(download: Download) {
|
fun remove(download: Download) {
|
||||||
val removed = queue.remove(download)
|
_state.update {
|
||||||
store.remove(download)
|
store.remove(download)
|
||||||
download.statusSubject = null
|
|
||||||
download.statusCallback = null
|
|
||||||
if (download.status == Download.State.DOWNLOADING || download.status == Download.State.QUEUE) {
|
if (download.status == Download.State.DOWNLOADING || download.status == Download.State.QUEUE) {
|
||||||
download.status = Download.State.NOT_DOWNLOADED
|
download.status = Download.State.NOT_DOWNLOADED
|
||||||
}
|
}
|
||||||
if (removed) {
|
it - download
|
||||||
scope.launchNonCancellable {
|
|
||||||
_updates.send(Unit)
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
fun remove(chapter: Chapter) {
|
fun remove(chapter: Chapter) {
|
||||||
find { it.chapter.id == chapter.id }?.let { remove(it) }
|
_state.value.find { it.chapter.id == chapter.id }?.let { remove(it) }
|
||||||
}
|
}
|
||||||
|
|
||||||
fun remove(chapters: List<Chapter>) {
|
fun remove(chapters: List<Chapter>) {
|
||||||
@ -71,61 +50,50 @@ class DownloadQueue(
|
|||||||
}
|
}
|
||||||
|
|
||||||
fun remove(manga: Manga) {
|
fun remove(manga: Manga) {
|
||||||
filter { it.manga.id == manga.id }.forEach { remove(it) }
|
_state.value.filter { it.manga.id == manga.id }.forEach { remove(it) }
|
||||||
}
|
}
|
||||||
|
|
||||||
fun clear() {
|
fun clear() {
|
||||||
queue.forEach { download ->
|
_state.update {
|
||||||
download.statusSubject = null
|
it.forEach { download ->
|
||||||
download.statusCallback = null
|
|
||||||
if (download.status == Download.State.DOWNLOADING || download.status == Download.State.QUEUE) {
|
if (download.status == Download.State.DOWNLOADING || download.status == Download.State.QUEUE) {
|
||||||
download.status = Download.State.NOT_DOWNLOADED
|
download.status = Download.State.NOT_DOWNLOADED
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
queue.clear()
|
|
||||||
store.clear()
|
store.clear()
|
||||||
scope.launchNonCancellable {
|
emptyList()
|
||||||
_updates.send(Unit)
|
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
fun statusFlow(): Flow<Download> = getStatusObservable().asFlow()
|
fun statusFlow(): Flow<Download> = state
|
||||||
|
.flatMapLatest { downloads ->
|
||||||
|
downloads
|
||||||
|
.map { download ->
|
||||||
|
download.statusFlow.drop(1).map { download }
|
||||||
|
}
|
||||||
|
.merge()
|
||||||
|
}
|
||||||
|
.onStart { emitAll(getActiveDownloads()) }
|
||||||
|
|
||||||
fun progressFlow(): Flow<Download> = getProgressObservable().asFlow()
|
fun progressFlow(): Flow<Download> = state
|
||||||
|
.flatMapLatest { downloads ->
|
||||||
|
downloads
|
||||||
|
.map { download ->
|
||||||
|
download.progressFlow.drop(1).map { download }
|
||||||
|
}
|
||||||
|
.merge()
|
||||||
|
}
|
||||||
|
.onStart { emitAll(getActiveDownloads()) }
|
||||||
|
|
||||||
private fun getActiveDownloads(): Observable<Download> =
|
private fun getActiveDownloads(): Flow<Download> =
|
||||||
Observable.from(this).filter { download -> download.status == Download.State.DOWNLOADING }
|
_state.value.filter { download -> download.status == Download.State.DOWNLOADING }.asFlow()
|
||||||
|
|
||||||
private fun getStatusObservable(): Observable<Download> = statusSubject
|
fun count(predicate: (Download) -> Boolean) = _state.value.count(predicate)
|
||||||
.startWith(getActiveDownloads())
|
fun filter(predicate: (Download) -> Boolean) = _state.value.filter(predicate)
|
||||||
.onBackpressureBuffer()
|
fun find(predicate: (Download) -> Boolean) = _state.value.find(predicate)
|
||||||
|
fun <K> groupBy(keySelector: (Download) -> K) = _state.value.groupBy(keySelector)
|
||||||
private fun getProgressObservable(): Observable<Download> {
|
fun isEmpty() = _state.value.isEmpty()
|
||||||
return statusSubject.onBackpressureBuffer()
|
fun isNotEmpty() = _state.value.isNotEmpty()
|
||||||
.startWith(getActiveDownloads())
|
fun none(predicate: (Download) -> Boolean) = _state.value.none(predicate)
|
||||||
.flatMap { download ->
|
fun toMutableList() = _state.value.toMutableList()
|
||||||
if (download.status == Download.State.DOWNLOADING) {
|
|
||||||
val pageStatusSubject = PublishSubject.create<Page.State>()
|
|
||||||
setPagesSubject(download.pages, pageStatusSubject)
|
|
||||||
return@flatMap pageStatusSubject
|
|
||||||
.onBackpressureBuffer()
|
|
||||||
.filter { it == Page.State.READY }
|
|
||||||
.map { download }
|
|
||||||
} else if (download.status == Download.State.DOWNLOADED || download.status == Download.State.ERROR) {
|
|
||||||
setPagesSubject(download.pages, null)
|
|
||||||
}
|
|
||||||
Observable.just(download)
|
|
||||||
}
|
|
||||||
.filter { it.status == Download.State.DOWNLOADING }
|
|
||||||
}
|
|
||||||
|
|
||||||
private fun setPagesFor(download: Download) {
|
|
||||||
if (download.status == Download.State.DOWNLOADED || download.status == Download.State.ERROR) {
|
|
||||||
setPagesSubject(download.pages, null)
|
|
||||||
}
|
|
||||||
}
|
|
||||||
|
|
||||||
private fun setPagesSubject(pages: List<Page>?, subject: PublishSubject<Page.State>?) {
|
|
||||||
pages?.forEach { it.statusSubject = subject }
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
|
@ -14,7 +14,6 @@ import kotlinx.coroutines.Job
|
|||||||
import kotlinx.coroutines.delay
|
import kotlinx.coroutines.delay
|
||||||
import kotlinx.coroutines.flow.MutableStateFlow
|
import kotlinx.coroutines.flow.MutableStateFlow
|
||||||
import kotlinx.coroutines.flow.asStateFlow
|
import kotlinx.coroutines.flow.asStateFlow
|
||||||
import kotlinx.coroutines.flow.catch
|
|
||||||
import kotlinx.coroutines.flow.collectLatest
|
import kotlinx.coroutines.flow.collectLatest
|
||||||
import kotlinx.coroutines.flow.combine
|
import kotlinx.coroutines.flow.combine
|
||||||
import kotlinx.coroutines.flow.debounce
|
import kotlinx.coroutines.flow.debounce
|
||||||
@ -22,8 +21,6 @@ import kotlinx.coroutines.flow.distinctUntilChanged
|
|||||||
import kotlinx.coroutines.flow.map
|
import kotlinx.coroutines.flow.map
|
||||||
import kotlinx.coroutines.flow.update
|
import kotlinx.coroutines.flow.update
|
||||||
import kotlinx.coroutines.launch
|
import kotlinx.coroutines.launch
|
||||||
import logcat.LogPriority
|
|
||||||
import tachiyomi.core.util.system.logcat
|
|
||||||
import uy.kohesive.injekt.Injekt
|
import uy.kohesive.injekt.Injekt
|
||||||
import uy.kohesive.injekt.api.get
|
import uy.kohesive.injekt.api.get
|
||||||
|
|
||||||
@ -116,8 +113,7 @@ class DownloadQueueScreenModel(
|
|||||||
|
|
||||||
init {
|
init {
|
||||||
coroutineScope.launch {
|
coroutineScope.launch {
|
||||||
downloadManager.queue.updates
|
downloadManager.queue.state
|
||||||
.catch { logcat(LogPriority.ERROR, it) }
|
|
||||||
.map { downloads ->
|
.map { downloads ->
|
||||||
downloads
|
downloads
|
||||||
.groupBy { it.source }
|
.groupBy { it.source }
|
||||||
|
@ -95,14 +95,13 @@ private class MoreScreenModel(
|
|||||||
coroutineScope.launchIO {
|
coroutineScope.launchIO {
|
||||||
combine(
|
combine(
|
||||||
DownloadService.isRunning,
|
DownloadService.isRunning,
|
||||||
downloadManager.queue.updates,
|
downloadManager.queue.state,
|
||||||
) { isRunning, downloadQueue -> Pair(isRunning, downloadQueue.size) }
|
) { isRunning, downloadQueue -> Pair(isRunning, downloadQueue.size) }
|
||||||
.collectLatest { (isDownloading, downloadQueueSize) ->
|
.collectLatest { (isDownloading, downloadQueueSize) ->
|
||||||
val pendingDownloadExists = downloadQueueSize != 0
|
val pendingDownloadExists = downloadQueueSize != 0
|
||||||
_state.value = when {
|
_state.value = when {
|
||||||
!pendingDownloadExists -> DownloadQueueState.Stopped
|
!pendingDownloadExists -> DownloadQueueState.Stopped
|
||||||
!isDownloading && !pendingDownloadExists -> DownloadQueueState.Paused(0)
|
!isDownloading -> DownloadQueueState.Paused(downloadQueueSize)
|
||||||
!isDownloading && pendingDownloadExists -> DownloadQueueState.Paused(downloadQueueSize)
|
|
||||||
else -> DownloadQueueState.Downloading(downloadQueueSize)
|
else -> DownloadQueueState.Downloading(downloadQueueSize)
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -6,7 +6,6 @@ import kotlinx.coroutines.flow.MutableStateFlow
|
|||||||
import kotlinx.coroutines.flow.asStateFlow
|
import kotlinx.coroutines.flow.asStateFlow
|
||||||
import kotlinx.serialization.Serializable
|
import kotlinx.serialization.Serializable
|
||||||
import kotlinx.serialization.Transient
|
import kotlinx.serialization.Transient
|
||||||
import rx.subjects.Subject
|
|
||||||
|
|
||||||
@Serializable
|
@Serializable
|
||||||
open class Page(
|
open class Page(
|
||||||
@ -28,7 +27,6 @@ open class Page(
|
|||||||
get() = _statusFlow.value
|
get() = _statusFlow.value
|
||||||
set(value) {
|
set(value) {
|
||||||
_statusFlow.value = value
|
_statusFlow.value = value
|
||||||
statusSubject?.onNext(value)
|
|
||||||
}
|
}
|
||||||
|
|
||||||
@Transient
|
@Transient
|
||||||
@ -42,9 +40,6 @@ open class Page(
|
|||||||
_progressFlow.value = value
|
_progressFlow.value = value
|
||||||
}
|
}
|
||||||
|
|
||||||
@Transient
|
|
||||||
var statusSubject: Subject<State, State>? = null
|
|
||||||
|
|
||||||
override fun update(bytesRead: Long, contentLength: Long, done: Boolean) {
|
override fun update(bytesRead: Long, contentLength: Long, done: Boolean) {
|
||||||
progress = if (contentLength > 0) {
|
progress = if (contentLength > 0) {
|
||||||
(100 * bytesRead / contentLength).toInt()
|
(100 * bytesRead / contentLength).toInt()
|
||||||
|
Loading…
Reference in New Issue
Block a user