ImageDownloader.swift 20 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457458459460461462463464465466467468469470471472473474475476477478479480481482483484485486487488489490491492493494495496497498499500501502
  1. //
  2. // ImageDownloader.swift
  3. // Kingfisher
  4. //
  5. // Created by Wei Wang on 15/4/6.
  6. //
  7. // Copyright (c) 2019 Wei Wang <onevcat@gmail.com>
  8. //
  9. // Permission is hereby granted, free of charge, to any person obtaining a copy
  10. // of this software and associated documentation files (the "Software"), to deal
  11. // in the Software without restriction, including without limitation the rights
  12. // to use, copy, modify, merge, publish, distribute, sublicense, and/or sell
  13. // copies of the Software, and to permit persons to whom the Software is
  14. // furnished to do so, subject to the following conditions:
  15. //
  16. // The above copyright notice and this permission notice shall be included in
  17. // all copies or substantial portions of the Software.
  18. //
  19. // THE SOFTWARE IS PROVIDED "AS IS", WITHOUT WARRANTY OF ANY KIND, EXPRESS OR
  20. // IMPLIED, INCLUDING BUT NOT LIMITED TO THE WARRANTIES OF MERCHANTABILITY,
  21. // FITNESS FOR A PARTICULAR PURPOSE AND NONINFRINGEMENT. IN NO EVENT SHALL THE
  22. // AUTHORS OR COPYRIGHT HOLDERS BE LIABLE FOR ANY CLAIM, DAMAGES OR OTHER
  23. // LIABILITY, WHETHER IN AN ACTION OF CONTRACT, TORT OR OTHERWISE, ARISING FROM,
  24. // OUT OF OR IN CONNECTION WITH THE SOFTWARE OR THE USE OR OTHER DEALINGS IN
  25. // THE SOFTWARE.
  26. #if os(macOS)
  27. import AppKit
  28. #else
  29. import UIKit
  30. #endif
  31. typealias DownloadResult = Result<ImageLoadingResult, KingfisherError>
  32. /// Represents a success result of an image downloading progress.
  33. public struct ImageLoadingResult {
  34. /// The downloaded image.
  35. public let image: KFCrossPlatformImage
  36. /// Original URL of the image request.
  37. public let url: URL?
  38. /// The raw data received from downloader.
  39. public let originalData: Data
  40. /// Creates an `ImageDownloadResult`
  41. ///
  42. /// - parameter image: Image of the download result
  43. /// - parameter url: URL from where the image was downloaded from
  44. /// - parameter originalData: The image's binary data
  45. public init(image: KFCrossPlatformImage, url: URL? = nil, originalData: Data) {
  46. self.image = image
  47. self.url = url
  48. self.originalData = originalData
  49. }
  50. }
  51. /// Represents a task of an image downloading process.
  52. public struct DownloadTask {
  53. /// The `SessionDataTask` object bounded to this download task. Multiple `DownloadTask`s could refer
  54. /// to a same `sessionTask`. This is an optimization in Kingfisher to prevent multiple downloading task
  55. /// for the same URL resource at the same time.
  56. ///
  57. /// When you `cancel` a `DownloadTask`, this `SessionDataTask` and its cancel token will be pass through.
  58. /// You can use them to identify the cancelled task.
  59. public let sessionTask: SessionDataTask
  60. /// The cancel token which is used to cancel the task. This is only for identify the task when it is cancelled.
  61. /// To cancel a `DownloadTask`, use `cancel` instead.
  62. public let cancelToken: SessionDataTask.CancelToken
  63. /// Cancel this task if it is running. It will do nothing if this task is not running.
  64. ///
  65. /// - Note:
  66. /// In Kingfisher, there is an optimization to prevent starting another download task if the target URL is being
  67. /// downloading. However, even when internally no new session task created, a `DownloadTask` will be still created
  68. /// and returned when you call related methods, but it will share the session downloading task with a previous task.
  69. /// In this case, if multiple `DownloadTask`s share a single session download task, cancelling a `DownloadTask`
  70. /// does not affect other `DownloadTask`s.
  71. ///
  72. /// If you need to cancel all `DownloadTask`s of a url, use `ImageDownloader.cancel(url:)`. If you need to cancel
  73. /// all downloading tasks of an `ImageDownloader`, use `ImageDownloader.cancelAll()`.
  74. public func cancel() {
  75. sessionTask.cancel(token: cancelToken)
  76. }
  77. }
  78. extension DownloadTask {
  79. enum WrappedTask {
  80. case download(DownloadTask)
  81. case dataProviding
  82. func cancel() {
  83. switch self {
  84. case .download(let task): task.cancel()
  85. case .dataProviding: break
  86. }
  87. }
  88. var value: DownloadTask? {
  89. switch self {
  90. case .download(let task): return task
  91. case .dataProviding: return nil
  92. }
  93. }
  94. }
  95. }
  96. /// Represents a downloading manager for requesting the image with a URL from server.
  97. open class ImageDownloader {
  98. // MARK: Singleton
  99. /// The default downloader.
  100. public static let `default` = ImageDownloader(name: "default")
  101. // MARK: Public Properties
  102. /// The duration before the downloading is timeout. Default is 15 seconds.
  103. open var downloadTimeout: TimeInterval = 15.0
  104. /// A set of trusted hosts when receiving server trust challenges. A challenge with host name contained in this
  105. /// set will be ignored. You can use this set to specify the self-signed site. It only will be used if you don't
  106. /// specify the `authenticationChallengeResponder`.
  107. ///
  108. /// If `authenticationChallengeResponder` is set, this property will be ignored and the implementation of
  109. /// `authenticationChallengeResponder` will be used instead.
  110. open var trustedHosts: Set<String>?
  111. /// Use this to set supply a configuration for the downloader. By default,
  112. /// NSURLSessionConfiguration.ephemeralSessionConfiguration() will be used.
  113. ///
  114. /// You could change the configuration before a downloading task starts.
  115. /// A configuration without persistent storage for caches is requested for downloader working correctly.
  116. open var sessionConfiguration = URLSessionConfiguration.ephemeral {
  117. didSet {
  118. session.invalidateAndCancel()
  119. session = URLSession(configuration: sessionConfiguration, delegate: sessionDelegate, delegateQueue: nil)
  120. }
  121. }
  122. open var sessionDelegate: SessionDelegate {
  123. didSet {
  124. session.invalidateAndCancel()
  125. session = URLSession(configuration: sessionConfiguration, delegate: sessionDelegate, delegateQueue: nil)
  126. setupSessionHandler()
  127. }
  128. }
  129. /// Whether the download requests should use pipeline or not. Default is false.
  130. open var requestsUsePipelining = false
  131. /// Delegate of this `ImageDownloader` object. See `ImageDownloaderDelegate` protocol for more.
  132. open weak var delegate: ImageDownloaderDelegate?
  133. /// A responder for authentication challenge.
  134. /// Downloader will forward the received authentication challenge for the downloading session to this responder.
  135. open weak var authenticationChallengeResponder: AuthenticationChallengeResponsible?
  136. private let name: String
  137. private var session: URLSession
  138. // MARK: Initializers
  139. /// Creates a downloader with name.
  140. ///
  141. /// - Parameter name: The name for the downloader. It should not be empty.
  142. public init(name: String) {
  143. if name.isEmpty {
  144. fatalError("[Kingfisher] You should specify a name for the downloader. "
  145. + "A downloader with empty name is not permitted.")
  146. }
  147. self.name = name
  148. sessionDelegate = SessionDelegate()
  149. session = URLSession(
  150. configuration: sessionConfiguration,
  151. delegate: sessionDelegate,
  152. delegateQueue: nil)
  153. authenticationChallengeResponder = self
  154. setupSessionHandler()
  155. }
  156. deinit { session.invalidateAndCancel() }
  157. private func setupSessionHandler() {
  158. sessionDelegate.onReceiveSessionChallenge.delegate(on: self) { (self, invoke) in
  159. self.authenticationChallengeResponder?.downloader(self, didReceive: invoke.1, completionHandler: invoke.2)
  160. }
  161. sessionDelegate.onReceiveSessionTaskChallenge.delegate(on: self) { (self, invoke) in
  162. self.authenticationChallengeResponder?.downloader(
  163. self, task: invoke.1, didReceive: invoke.2, completionHandler: invoke.3)
  164. }
  165. sessionDelegate.onValidStatusCode.delegate(on: self) { (self, code) in
  166. return (self.delegate ?? self).isValidStatusCode(code, for: self)
  167. }
  168. sessionDelegate.onResponseReceived.delegate(on: self) { (self, invoke) in
  169. (self.delegate ?? self).imageDownloader(self, didReceive: invoke.0, completionHandler: invoke.1)
  170. }
  171. sessionDelegate.onDownloadingFinished.delegate(on: self) { (self, value) in
  172. let (url, result) = value
  173. do {
  174. let value = try result.get()
  175. self.delegate?.imageDownloader(self, didFinishDownloadingImageForURL: url, with: value, error: nil)
  176. } catch {
  177. self.delegate?.imageDownloader(self, didFinishDownloadingImageForURL: url, with: nil, error: error)
  178. }
  179. }
  180. sessionDelegate.onDidDownloadData.delegate(on: self) { (self, task) in
  181. return (self.delegate ?? self).imageDownloader(self, didDownload: task.mutableData, with: task)
  182. }
  183. }
  184. // Wraps `completionHandler` to `onCompleted` respectively.
  185. private func createCompletionCallBack(_ completionHandler: ((DownloadResult) -> Void)?) -> Delegate<DownloadResult, Void>? {
  186. return completionHandler.map { block -> Delegate<DownloadResult, Void> in
  187. let delegate = Delegate<Result<ImageLoadingResult, KingfisherError>, Void>()
  188. delegate.delegate(on: self) { (self, callback) in
  189. block(callback)
  190. }
  191. return delegate
  192. }
  193. }
  194. private func createTaskCallback(
  195. _ completionHandler: ((DownloadResult) -> Void)?,
  196. options: KingfisherParsedOptionsInfo
  197. ) -> SessionDataTask.TaskCallback
  198. {
  199. return SessionDataTask.TaskCallback(
  200. onCompleted: createCompletionCallBack(completionHandler),
  201. options: options
  202. )
  203. }
  204. private func createDownloadContext(
  205. with url: URL,
  206. options: KingfisherParsedOptionsInfo,
  207. done: @escaping ((Result<DownloadingContext, KingfisherError>) -> Void)
  208. )
  209. {
  210. func checkRequestAndDone(r: URLRequest) {
  211. // There is a possibility that request modifier changed the url to `nil` or empty.
  212. // In this case, throw an error.
  213. guard let url = r.url, !url.absoluteString.isEmpty else {
  214. done(.failure(KingfisherError.requestError(reason: .invalidURL(request: r))))
  215. return
  216. }
  217. done(.success(DownloadingContext(url: url, request: r, options: options)))
  218. }
  219. // Creates default request.
  220. var request = URLRequest(url: url, cachePolicy: .reloadIgnoringLocalCacheData, timeoutInterval: downloadTimeout)
  221. request.httpShouldUsePipelining = requestsUsePipelining
  222. if #available(macOS 10.15, iOS 13.0, watchOS 6.0, tvOS 13.0, *) , options.lowDataModeSource != nil {
  223. request.allowsConstrainedNetworkAccess = false
  224. }
  225. if let requestModifier = options.requestModifier {
  226. // Modifies request before sending.
  227. requestModifier.modified(for: request) { result in
  228. guard let finalRequest = result else {
  229. done(.failure(KingfisherError.requestError(reason: .emptyRequest)))
  230. return
  231. }
  232. checkRequestAndDone(r: finalRequest)
  233. }
  234. } else {
  235. checkRequestAndDone(r: request)
  236. }
  237. }
  238. private func addDownloadTask(
  239. context: DownloadingContext,
  240. callback: SessionDataTask.TaskCallback
  241. ) -> DownloadTask
  242. {
  243. // Ready to start download. Add it to session task manager (`sessionHandler`)
  244. let downloadTask: DownloadTask
  245. if let existingTask = sessionDelegate.task(for: context.url) {
  246. downloadTask = sessionDelegate.append(existingTask, callback: callback)
  247. } else {
  248. let sessionDataTask = session.dataTask(with: context.request)
  249. sessionDataTask.priority = context.options.downloadPriority
  250. downloadTask = sessionDelegate.add(sessionDataTask, url: context.url, callback: callback)
  251. }
  252. return downloadTask
  253. }
  254. private func reportWillDownloadImage(url: URL, request: URLRequest) {
  255. delegate?.imageDownloader(self, willDownloadImageForURL: url, with: request)
  256. }
  257. private func reportDidDownloadImageData(result: Result<(Data, URLResponse?), KingfisherError>, url: URL) {
  258. var response: URLResponse?
  259. var err: Error?
  260. do {
  261. response = try result.get().1
  262. } catch {
  263. err = error
  264. }
  265. self.delegate?.imageDownloader(
  266. self,
  267. didFinishDownloadingImageForURL: url,
  268. with: response,
  269. error: err
  270. )
  271. }
  272. private func reportDidProcessImage(
  273. result: Result<KFCrossPlatformImage, KingfisherError>, url: URL, response: URLResponse?
  274. )
  275. {
  276. if let image = try? result.get() {
  277. self.delegate?.imageDownloader(self, didDownload: image, for: url, with: response)
  278. }
  279. }
  280. private func startDownloadTask(
  281. context: DownloadingContext,
  282. callback: SessionDataTask.TaskCallback
  283. ) -> DownloadTask
  284. {
  285. let downloadTask = addDownloadTask(context: context, callback: callback)
  286. let sessionTask = downloadTask.sessionTask
  287. guard !sessionTask.started else {
  288. return downloadTask
  289. }
  290. sessionTask.onTaskDone.delegate(on: self) { (self, done) in
  291. // Underlying downloading finishes.
  292. // result: Result<(Data, URLResponse?)>, callbacks: [TaskCallback]
  293. let (result, callbacks) = done
  294. // Before processing the downloaded data.
  295. self.reportDidDownloadImageData(result: result, url: context.url)
  296. switch result {
  297. // Download finished. Now process the data to an image.
  298. case .success(let (data, response)):
  299. let processor = ImageDataProcessor(
  300. data: data, callbacks: callbacks, processingQueue: context.options.processingQueue
  301. )
  302. processor.onImageProcessed.delegate(on: self) { (self, done) in
  303. // `onImageProcessed` will be called for `callbacks.count` times, with each
  304. // `SessionDataTask.TaskCallback` as the input parameter.
  305. // result: Result<Image>, callback: SessionDataTask.TaskCallback
  306. let (result, callback) = done
  307. self.reportDidProcessImage(result: result, url: context.url, response: response)
  308. let imageResult = result.map { ImageLoadingResult(image: $0, url: context.url, originalData: data) }
  309. let queue = callback.options.callbackQueue
  310. queue.execute { callback.onCompleted?.call(imageResult) }
  311. }
  312. processor.process()
  313. case .failure(let error):
  314. callbacks.forEach { callback in
  315. let queue = callback.options.callbackQueue
  316. queue.execute { callback.onCompleted?.call(.failure(error)) }
  317. }
  318. }
  319. }
  320. reportWillDownloadImage(url: context.url, request: context.request)
  321. sessionTask.resume()
  322. return downloadTask
  323. }
  324. // MARK: Downloading Task
  325. /// Downloads an image with a URL and option. Invoked internally by Kingfisher. Subclasses must invoke super.
  326. ///
  327. /// - Parameters:
  328. /// - url: Target URL.
  329. /// - options: The options could control download behavior. See `KingfisherOptionsInfo`.
  330. /// - completionHandler: Called when the download progress finishes. This block will be called in the queue
  331. /// defined in `.callbackQueue` in `options` parameter.
  332. /// - Returns: A downloading task. You could call `cancel` on it to stop the download task.
  333. @discardableResult
  334. open func downloadImage(
  335. with url: URL,
  336. options: KingfisherParsedOptionsInfo,
  337. completionHandler: ((Result<ImageLoadingResult, KingfisherError>) -> Void)? = nil) -> DownloadTask?
  338. {
  339. var downloadTask: DownloadTask?
  340. createDownloadContext(with: url, options: options) { result in
  341. switch result {
  342. case .success(let context):
  343. // `downloadTask` will be set if the downloading started immediately. This is the case when no request
  344. // modifier or a sync modifier (`ImageDownloadRequestModifier`) is used. Otherwise, when an
  345. // `AsyncImageDownloadRequestModifier` is used the returned `downloadTask` of this method will be `nil`
  346. // and the actual "delayed" task is given in `AsyncImageDownloadRequestModifier.onDownloadTaskStarted`
  347. // callback.
  348. downloadTask = self.startDownloadTask(
  349. context: context,
  350. callback: self.createTaskCallback(completionHandler, options: options)
  351. )
  352. if let modifier = options.requestModifier {
  353. modifier.onDownloadTaskStarted?(downloadTask)
  354. }
  355. case .failure(let error):
  356. options.callbackQueue.execute {
  357. completionHandler?(.failure(error))
  358. }
  359. }
  360. }
  361. return downloadTask
  362. }
  363. /// Downloads an image with a URL and option.
  364. ///
  365. /// - Parameters:
  366. /// - url: Target URL.
  367. /// - options: The options could control download behavior. See `KingfisherOptionsInfo`.
  368. /// - progressBlock: Called when the download progress updated. This block will be always be called in main queue.
  369. /// - completionHandler: Called when the download progress finishes. This block will be called in the queue
  370. /// defined in `.callbackQueue` in `options` parameter.
  371. /// - Returns: A downloading task. You could call `cancel` on it to stop the download task.
  372. @discardableResult
  373. open func downloadImage(
  374. with url: URL,
  375. options: KingfisherOptionsInfo? = nil,
  376. progressBlock: DownloadProgressBlock? = nil,
  377. completionHandler: ((Result<ImageLoadingResult, KingfisherError>) -> Void)? = nil) -> DownloadTask?
  378. {
  379. var info = KingfisherParsedOptionsInfo(options)
  380. if let block = progressBlock {
  381. info.onDataReceived = (info.onDataReceived ?? []) + [ImageLoadingProgressSideEffect(block)]
  382. }
  383. return downloadImage(
  384. with: url,
  385. options: info,
  386. completionHandler: completionHandler)
  387. }
  388. /// Downloads an image with a URL and option.
  389. ///
  390. /// - Parameters:
  391. /// - url: Target URL.
  392. /// - options: The options could control download behavior. See `KingfisherOptionsInfo`.
  393. /// - completionHandler: Called when the download progress finishes. This block will be called in the queue
  394. /// defined in `.callbackQueue` in `options` parameter.
  395. /// - Returns: A downloading task. You could call `cancel` on it to stop the download task.
  396. @discardableResult
  397. open func downloadImage(
  398. with url: URL,
  399. options: KingfisherOptionsInfo? = nil,
  400. completionHandler: ((Result<ImageLoadingResult, KingfisherError>) -> Void)? = nil) -> DownloadTask?
  401. {
  402. downloadImage(
  403. with: url,
  404. options: KingfisherParsedOptionsInfo(options),
  405. completionHandler: completionHandler
  406. )
  407. }
  408. }
  409. // MARK: Cancelling Task
  410. extension ImageDownloader {
  411. /// Cancel all downloading tasks for this `ImageDownloader`. It will trigger the completion handlers
  412. /// for all not-yet-finished downloading tasks.
  413. ///
  414. /// If you need to only cancel a certain task, call `cancel()` on the `DownloadTask`
  415. /// returned by the downloading methods. If you need to cancel all `DownloadTask`s of a certain url,
  416. /// use `ImageDownloader.cancel(url:)`.
  417. public func cancelAll() {
  418. sessionDelegate.cancelAll()
  419. }
  420. /// Cancel all downloading tasks for a given URL. It will trigger the completion handlers for
  421. /// all not-yet-finished downloading tasks for the URL.
  422. ///
  423. /// - Parameter url: The URL which you want to cancel downloading.
  424. public func cancel(url: URL) {
  425. sessionDelegate.cancel(url: url)
  426. }
  427. }
  428. // Use the default implementation from extension of `AuthenticationChallengeResponsible`.
  429. extension ImageDownloader: AuthenticationChallengeResponsible {}
  430. // Use the default implementation from extension of `ImageDownloaderDelegate`.
  431. extension ImageDownloader: ImageDownloaderDelegate {}
  432. extension ImageDownloader {
  433. struct DownloadingContext {
  434. let url: URL
  435. let request: URLRequest
  436. let options: KingfisherParsedOptionsInfo
  437. }
  438. }