buffer.go 13 KB

123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429430431432433434435436437438439440441442443444445446447448449450451452453454455456457
  1. // Package asyncbuffer provides an asynchronous buffer that reads data from an
  2. // io.Reader in the background.
  3. //
  4. // When created, AsyncBuffer starts reading from the upstream reader in the
  5. // background. If a read error occurs, it is stored and can be checked with
  6. // AsyncBuffer.Error().
  7. //
  8. // When reading through AsyncBuffer.Reader().Read(), the error is only returned
  9. // once the reader reaches the point where the error occurred. In other words,
  10. // errors are delayed until encountered by the reader.
  11. //
  12. // However, AsyncBuffer.Close() and AsyncBuffer.Error() will immediately return
  13. // any stored error, even if the reader has not yet reached the error point.
  14. package asyncbuffer
  15. import (
  16. "context"
  17. "errors"
  18. "io"
  19. "log/slog"
  20. "sync"
  21. "sync/atomic"
  22. "github.com/imgproxy/imgproxy/v3/ierrors"
  23. "github.com/imgproxy/imgproxy/v3/ioutil"
  24. )
  25. const (
  26. // chunkSize is the size of each chunk in bytes
  27. chunkSize = 4096
  28. // pauseThreshold is the size of the file which is always read to memory. Data beyond the
  29. // threshold is read only if accessed. If not a multiple of chunkSize, the last chunk it points
  30. // to is read in full.
  31. pauseThreshold = 32768 // 32 KiB
  32. )
  33. // byteChunk is a struct that holds a buffer and the data read from the upstream reader
  34. // data slice is required since the chunk read may be smaller than ChunkSize
  35. type byteChunk struct {
  36. buf []byte
  37. data []byte
  38. }
  39. // chunkPool is a global sync.Pool that holds byteChunk objects for
  40. // all readers
  41. var chunkPool = sync.Pool{
  42. New: func() any {
  43. buf := make([]byte, chunkSize)
  44. return &byteChunk{
  45. buf: buf,
  46. data: buf[:0],
  47. }
  48. },
  49. }
  50. // AsyncBuffer is a wrapper around io.Reader that reads data in chunks
  51. // in background and allows reading from synchronously.
  52. type AsyncBuffer struct {
  53. r io.ReadCloser // Upstream reader
  54. dataLen int // Expected length of the data in r, <= 0 means unknown length
  55. chunks []*byteChunk // References to the chunks read from the upstream reader
  56. mu sync.RWMutex // Mutex on chunks slice
  57. err atomic.Value // Error that occurred during reading
  58. bytesRead atomic.Int64 // Total length of the data read
  59. finished atomic.Bool // Indicates that the buffer has finished reading
  60. closed atomic.Bool // Indicates that the buffer was closed
  61. paused *Latch // Paused buffer does not read data beyond threshold
  62. chunkCond *Cond // Ticker that signals when a new chunk is ready
  63. finishOnce sync.Once
  64. finishFn []context.CancelFunc
  65. }
  66. // New creates a new AsyncBuffer that reads from the given io.ReadCloser in background
  67. // and closes it when finished.
  68. //
  69. // r - io.ReadCloser to read data from
  70. // dataLen - expected length of the data in r, <= 0 means unknown length
  71. // finishFn - optional functions to call when the buffer is finished reading
  72. func New(r io.ReadCloser, dataLen int, finishFn ...context.CancelFunc) *AsyncBuffer {
  73. ab := &AsyncBuffer{
  74. r: r,
  75. dataLen: dataLen,
  76. paused: NewLatch(),
  77. chunkCond: NewCond(),
  78. finishFn: finishFn,
  79. }
  80. go ab.readChunks()
  81. return ab
  82. }
  83. // callFinishFn calls the finish functions registered with the AsyncBuffer.
  84. func (ab *AsyncBuffer) callFinishFn() {
  85. ab.finishOnce.Do(func() {
  86. for _, fn := range ab.finishFn {
  87. if fn != nil {
  88. fn()
  89. }
  90. }
  91. })
  92. }
  93. func (ab *AsyncBuffer) setErr(err error) {
  94. if err == nil {
  95. return
  96. }
  97. // If the error is already set, we do not overwrite it
  98. if ab.err.Load() == nil {
  99. ab.err.Store(ierrors.Wrap(err, 1))
  100. }
  101. }
  102. // addChunk adds a new chunk to the AsyncBuffer, increments bytesRead
  103. // and signals that a chunk is ready
  104. func (ab *AsyncBuffer) addChunk(chunk *byteChunk) {
  105. ab.mu.Lock()
  106. defer ab.mu.Unlock()
  107. if ab.closed.Load() {
  108. // If the reader is closed, we return the chunk to the pool
  109. chunkPool.Put(chunk)
  110. return
  111. }
  112. // Store the chunk, increase chunk size, increase length of the data read
  113. ab.chunks = append(ab.chunks, chunk)
  114. ab.bytesRead.Add(int64(len(chunk.data)))
  115. ab.chunkCond.Tick()
  116. }
  117. // readChunks reads data from the upstream reader in background and stores them in the pool
  118. func (ab *AsyncBuffer) readChunks() {
  119. defer func() {
  120. if ab.bytesRead.Load() < int64(ab.dataLen) {
  121. // If the reader has finished reading and we have not read enough data,
  122. // set err to io.ErrUnexpectedEOF
  123. ab.setErr(io.ErrUnexpectedEOF)
  124. }
  125. // Indicate that the reader has finished reading
  126. ab.finished.Store(true)
  127. ab.chunkCond.Close()
  128. // Close the upstream reader
  129. if err := ab.r.Close(); err != nil {
  130. slog.Warn(
  131. "error closing upstream reader",
  132. "error", err,
  133. "source", "asyncbuffer.AsyncBuffer.readChunks",
  134. )
  135. }
  136. ab.callFinishFn()
  137. }()
  138. r := ab.r.(io.Reader)
  139. if ab.dataLen > 0 {
  140. // If the data length is known, we read only that much data
  141. r = io.LimitReader(r, int64(ab.dataLen))
  142. }
  143. // Stop reading if the reader is closed
  144. for !ab.closed.Load() {
  145. // In case we are trying to read data beyond threshold and we are paused,
  146. // wait for pause to be released.
  147. if ab.bytesRead.Load() >= pauseThreshold {
  148. ab.paused.Wait()
  149. // If the reader has been closed while waiting, we can stop reading
  150. if ab.closed.Load() {
  151. return // No more data to read
  152. }
  153. }
  154. // Get a chunk from the pool
  155. // If the pool is empty, it will create a new byteChunk with ChunkSize
  156. chunk, ok := chunkPool.Get().(*byteChunk)
  157. if !ok {
  158. ab.setErr(errors.New("asyncbuffer.AsyncBuffer.readChunks: failed to get chunk from pool"))
  159. return
  160. }
  161. // Read data into the chunk's buffer
  162. // There is no way to guarantee that r.Read will abort on context cancellation,
  163. // unfortunately, this is how golang works.
  164. n, err := ioutil.TryReadFull(r, chunk.buf)
  165. // If it's not the EOF, we need to store the error
  166. if err != nil && err != io.EOF {
  167. ab.setErr(err)
  168. chunkPool.Put(chunk)
  169. return
  170. }
  171. // No bytes were read (n == 0), we can return the chunk to the pool
  172. if n == 0 {
  173. chunkPool.Put(chunk)
  174. return
  175. }
  176. // Resize the chunk's data slice to the number of bytes read
  177. chunk.data = chunk.buf[:n]
  178. // Store the reference to the chunk in the AsyncBuffer
  179. ab.addChunk(chunk)
  180. // EOF at this point means that some bytes were read, but this is the
  181. // end of the stream, so we can stop reading
  182. if err == io.EOF {
  183. return
  184. }
  185. }
  186. }
  187. // closedError returns an error if the attempt to read on a closed reader was made.
  188. // If the reader had an error, it returns that error instead.
  189. func (ab *AsyncBuffer) closedError() error {
  190. // If the reader is closed, we return the error or nil
  191. if !ab.closed.Load() {
  192. return nil
  193. }
  194. err := ab.Error()
  195. if err == nil {
  196. err = errors.New("asyncbuffer.AsyncBuffer.ReadAt: attempt to read on closed reader")
  197. }
  198. return err
  199. }
  200. // offsetAvailable checks if the data at the given offset is available for reading.
  201. // It may return io.EOF if the reader is finished reading and the offset is beyond the end of the stream.
  202. func (ab *AsyncBuffer) offsetAvailable(off int64) (bool, error) {
  203. // We can not read data from the closed reader, none
  204. if err := ab.closedError(); err != nil {
  205. return false, err
  206. }
  207. // In case the offset falls within the already read chunks, we can return immediately,
  208. // even if error has occurred in the future
  209. if off < ab.bytesRead.Load() {
  210. return true, nil
  211. }
  212. // In case the reader is finished reading, and we have not read enough
  213. // data yet, return either error or EOF
  214. if ab.finished.Load() {
  215. // In case, error has occurred, we need to return it
  216. if err := ab.Error(); err != nil {
  217. return false, err
  218. }
  219. // Otherwise, it's EOF if the offset is beyond the end of the stream
  220. return false, io.EOF
  221. }
  222. // No available data
  223. return false, nil
  224. }
  225. // WaitFor waits for the data to be ready at the given offset. nil means ok.
  226. // It guarantees that the chunk at the given offset is ready to be read.
  227. func (ab *AsyncBuffer) WaitFor(off int64) error {
  228. // In case we are trying to read data which would potentially hit the pause threshold,
  229. // we need to unpause the reader ASAP.
  230. if off >= pauseThreshold {
  231. ab.paused.Release()
  232. }
  233. for {
  234. ok, err := ab.offsetAvailable(off)
  235. if ok || err != nil {
  236. return err
  237. }
  238. ab.chunkCond.Wait()
  239. }
  240. }
  241. // Wait waits for the reader to finish reading all data and returns
  242. // the total length of the data read.
  243. func (ab *AsyncBuffer) Wait() (int, error) {
  244. // Wait ends till the end of the stream: unpause the reader
  245. ab.paused.Release()
  246. for {
  247. // We can not read data from the closed reader
  248. if err := ab.closedError(); err != nil {
  249. return 0, err
  250. }
  251. // In case the reader is finished reading, we can return immediately
  252. if ab.finished.Load() {
  253. return int(ab.bytesRead.Load()), ab.Error()
  254. }
  255. // Lock until the next chunk is ready
  256. ab.chunkCond.Wait()
  257. }
  258. }
  259. // Error returns the error that occurred during reading data in background.
  260. func (ab *AsyncBuffer) Error() error {
  261. err := ab.err.Load()
  262. if err == nil {
  263. return nil
  264. }
  265. errCast, ok := err.(error)
  266. if !ok {
  267. return errors.New("asyncbuffer.AsyncBuffer.Error: failed to get error")
  268. }
  269. return errCast
  270. }
  271. // readChunkAt copies data from the chunk at the given absolute offset to the provided slice.
  272. // Chunk must be available when this method is called.
  273. // Returns the number of bytes copied to the slice or 0 if chunk has no data
  274. // (eg. offset is beyond the end of the stream).
  275. func (ab *AsyncBuffer) readChunkAt(p []byte, off int64) int {
  276. // If the chunk is not available, we return 0
  277. if off >= ab.bytesRead.Load() {
  278. return 0
  279. }
  280. ind := off / chunkSize // chunk index
  281. chunk := ab.chunks[ind]
  282. startOffset := off % chunkSize // starting offset in the chunk
  283. // If the offset in current chunk is greater than the data
  284. // it has, we return 0
  285. if startOffset >= int64(len(chunk.data)) {
  286. return 0
  287. }
  288. // Copy data to the target slice. The number of bytes to copy is limited by the
  289. // size of the target slice and the size of the data in the chunk.
  290. return copy(p, chunk.data[startOffset:])
  291. }
  292. // readAt reads data from the AsyncBuffer at the given offset.
  293. //
  294. // Please note that if pause threshold is hit in the middle of the reading,
  295. // the data beyond the threshold may not be available.
  296. //
  297. // If the reader is paused and we try to read data beyond the pause threshold,
  298. // it will wait till something could be returned.
  299. func (ab *AsyncBuffer) readAt(p []byte, off int64) (int, error) {
  300. size := int64(len(p)) // total size of the data to read
  301. if off < 0 {
  302. return 0, errors.New("asyncbuffer.AsyncBuffer.readAt: negative offset")
  303. }
  304. // If we plan to hit threshold while reading, release the paused reader
  305. if int64(len(p))+off > pauseThreshold {
  306. ab.paused.Release()
  307. }
  308. // Wait for the offset to be available.
  309. // It may return io.EOF if the offset is beyond the end of the stream.
  310. err := ab.WaitFor(off)
  311. if err != nil {
  312. return 0, err
  313. }
  314. // We lock the mutex until current buffer is read
  315. ab.mu.RLock()
  316. defer ab.mu.RUnlock()
  317. // If the reader is closed, we return an error
  318. if err := ab.closedError(); err != nil {
  319. return 0, err
  320. }
  321. // Read data from the first chunk
  322. n := ab.readChunkAt(p, off)
  323. if n == 0 {
  324. return 0, io.EOF // Failed to read any data: means we tried to read beyond the end of the stream
  325. }
  326. size -= int64(n)
  327. off += int64(n) // Here and beyond off always points to the last read byte + 1
  328. // Now, let's try to read the rest of the data from next chunks while they are available
  329. for size > 0 {
  330. // If data is not available at the given offset, we can return data read so far.
  331. ok, err := ab.offsetAvailable(off)
  332. if !ok {
  333. if err == io.EOF {
  334. return n, nil
  335. }
  336. return n, err
  337. }
  338. // Read data from the next chunk
  339. nX := ab.readChunkAt(p[n:], off)
  340. n += nX
  341. size -= int64(nX)
  342. off += int64(nX)
  343. // If we read data shorter than ChunkSize or, in case that was the last chunk, less than
  344. // the size of the tail, return kind of EOF
  345. if int64(nX) < min(size, int64(chunkSize)) {
  346. return n, nil
  347. }
  348. }
  349. return n, nil
  350. }
  351. // Close closes the AsyncBuffer and releases all resources.
  352. // It returns an error if the reader was already closed or if there was
  353. // an error during reading data in background even if none of the subsequent
  354. // readers have reached the position where the error occurred.
  355. func (ab *AsyncBuffer) Close() error {
  356. ab.mu.Lock()
  357. defer ab.mu.Unlock()
  358. // If the reader is already closed, we return immediately error or nil
  359. if ab.closed.Load() {
  360. return ab.Error()
  361. }
  362. ab.closed.Store(true)
  363. // Return all chunks to the pool
  364. for _, chunk := range ab.chunks {
  365. chunkPool.Put(chunk)
  366. }
  367. // Release the paused latch so that no goroutines are waiting for it
  368. ab.paused.Release()
  369. // Finish downloading
  370. ab.callFinishFn()
  371. return nil
  372. }
  373. // Reader returns an io.ReadSeeker+io.ReaderAt that can be used to read actual data from the AsyncBuffer
  374. func (ab *AsyncBuffer) Reader() *Reader {
  375. return &Reader{ab: ab, pos: 0}
  376. }