FFmpeg
pthread_frame.c
Go to the documentation of this file.
1 /*
2  * This file is part of FFmpeg.
3  *
4  * FFmpeg is free software; you can redistribute it and/or
5  * modify it under the terms of the GNU Lesser General Public
6  * License as published by the Free Software Foundation; either
7  * version 2.1 of the License, or (at your option) any later version.
8  *
9  * FFmpeg is distributed in the hope that it will be useful,
10  * but WITHOUT ANY WARRANTY; without even the implied warranty of
11  * MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE. See the GNU
12  * Lesser General Public License for more details.
13  *
14  * You should have received a copy of the GNU Lesser General Public
15  * License along with FFmpeg; if not, write to the Free Software
16  * Foundation, Inc., 51 Franklin Street, Fifth Floor, Boston, MA 02110-1301 USA
17  */
18 
19 /**
20  * @file
21  * Frame multithreading support functions
22  * @see doc/multithreading.txt
23  */
24 
25 #include "config.h"
26 
27 #include <stdatomic.h>
28 #include <stdint.h>
29 
30 #include "avcodec.h"
31 #include "avcodec_internal.h"
32 #include "codec_internal.h"
33 #include "decode.h"
34 #include "hwaccel_internal.h"
35 #include "hwconfig.h"
36 #include "internal.h"
37 #include "pthread_internal.h"
38 #include "refstruct.h"
39 #include "thread.h"
40 #include "threadframe.h"
41 #include "version_major.h"
42 
43 #include "libavutil/avassert.h"
44 #include "libavutil/buffer.h"
45 #include "libavutil/common.h"
46 #include "libavutil/cpu.h"
47 #include "libavutil/frame.h"
48 #include "libavutil/internal.h"
49 #include "libavutil/log.h"
50 #include "libavutil/mem.h"
51 #include "libavutil/opt.h"
52 #include "libavutil/thread.h"
53 
54 enum {
55  /// Set when the thread is awaiting a packet.
57  /// Set before the codec has called ff_thread_finish_setup().
59  /// Set after the codec has called ff_thread_finish_setup().
61 };
62 
63 enum {
64  UNINITIALIZED, ///< Thread has not been created, AVCodec->close mustn't be called
65  NEEDS_CLOSE, ///< FFCodec->close needs to be called
66  INITIALIZED, ///< Thread has been properly set up
67 };
68 
69 typedef struct ThreadFrameProgress {
72 
73 /**
74  * Context used by codec threads and stored in their AVCodecInternal thread_ctx.
75  */
76 typedef struct PerThreadContext {
78 
81  unsigned pthread_init_cnt;///< Number of successfully initialized mutexes/conditions
82  pthread_cond_t input_cond; ///< Used to wait for a new packet from the main thread.
83  pthread_cond_t progress_cond; ///< Used by child threads to wait for progress to change.
84  pthread_cond_t output_cond; ///< Used by the main thread to wait for frames to finish.
85 
86  pthread_mutex_t mutex; ///< Mutex used to protect the contents of the PerThreadContext.
87  pthread_mutex_t progress_mutex; ///< Mutex used to protect frame progress values and progress_cond.
88 
89  AVCodecContext *avctx; ///< Context used to decode packets passed to this thread.
90 
91  AVPacket *avpkt; ///< Input packet (for decoding) or output (for encoding).
92 
93  AVFrame *frame; ///< Output frame (for decoding) or input (for encoding).
94  int got_frame; ///< The output of got_picture_ptr from the last avcodec_decode_video() call.
95  int result; ///< The result of the last codec decode/encode() call.
96 
98 
99  int die; ///< Set when the thread should exit.
100 
103 
104  // set to 1 in ff_thread_finish_setup() when a threadsafe hwaccel is used;
105  // cannot check hwaccel caps directly, because
106  // worked threads clear hwaccel state for thread-unsafe hwaccels
107  // after each decode call
109 
110  atomic_int debug_threads; ///< Set if the FF_DEBUG_THREADS option is set.
112 
113 /**
114  * Context stored in the client AVCodecInternal thread_ctx.
115  */
116 typedef struct FrameThreadContext {
117  PerThreadContext *threads; ///< The contexts for each thread.
118  PerThreadContext *prev_thread; ///< The last thread submit_packet() was called on.
119 
120  unsigned pthread_init_cnt; ///< Number of successfully initialized mutexes/conditions
121  pthread_mutex_t buffer_mutex; ///< Mutex used to protect get/release_buffer().
122  /**
123  * This lock is used for ensuring threads run in serial when thread-unsafe
124  * hwaccel is used.
125  */
130 
131  int next_decoding; ///< The next context to submit a packet to.
132  int next_finished; ///< The next context to return output from.
133 
134  int delaying; /**<
135  * Set for the first N packets, where N is the number of threads.
136  * While it is set, ff_thread_en/decode_frame won't return any results.
137  */
138 
139  /* hwaccel state for thread-unsafe hwaccels is temporarily stored here in
140  * order to transfer its ownership to the next decoding thread without the
141  * need for extra synchronization */
146 
147 static int hwaccel_serial(const AVCodecContext *avctx)
148 {
149  return avctx->hwaccel && !(ffhwaccel(avctx->hwaccel)->caps_internal & HWACCEL_CAP_THREAD_SAFE);
150 }
151 
152 static void async_lock(FrameThreadContext *fctx)
153 {
155  while (fctx->async_lock)
156  pthread_cond_wait(&fctx->async_cond, &fctx->async_mutex);
157  fctx->async_lock = 1;
159 }
160 
162 {
164  av_assert0(fctx->async_lock);
165  fctx->async_lock = 0;
168 }
169 
171 {
172  AVCodecContext *avctx = p->avctx;
173  int idx = p - p->parent->threads;
174  char name[16];
175 
176  snprintf(name, sizeof(name), "av:%.7s:df%d", avctx->codec->name, idx);
177 
179 }
180 
181 /**
182  * Codec worker thread.
183  *
184  * Automatically calls ff_thread_finish_setup() if the codec does
185  * not provide an update_thread_context method, or if the codec returns
186  * before calling it.
187  */
189 {
190  PerThreadContext *p = arg;
191  AVCodecContext *avctx = p->avctx;
192  const FFCodec *codec = ffcodec(avctx->codec);
193 
194  thread_set_name(p);
195 
197  while (1) {
198  while (atomic_load(&p->state) == STATE_INPUT_READY && !p->die)
200 
201  if (p->die) break;
202 
203  if (!codec->update_thread_context)
204  ff_thread_finish_setup(avctx);
205 
206  /* If a decoder supports hwaccel, then it must call ff_get_format().
207  * Since that call must happen before ff_thread_finish_setup(), the
208  * decoder is required to implement update_thread_context() and call
209  * ff_thread_finish_setup() manually. Therefore the above
210  * ff_thread_finish_setup() call did not happen and hwaccel_serializing
211  * cannot be true here. */
213 
214  /* if the previous thread uses thread-unsafe hwaccel then we take the
215  * lock to ensure the threads don't run concurrently */
216  if (hwaccel_serial(avctx)) {
218  p->hwaccel_serializing = 1;
219  }
220 
221  av_frame_unref(p->frame);
222  p->got_frame = 0;
223  p->result = codec->cb.decode(avctx, p->frame, &p->got_frame, p->avpkt);
224 
225  if ((p->result < 0 || !p->got_frame) && p->frame->buf[0])
226  av_frame_unref(p->frame);
227 
228  if (atomic_load(&p->state) == STATE_SETTING_UP)
229  ff_thread_finish_setup(avctx);
230 
231  if (p->hwaccel_serializing) {
232  /* wipe hwaccel state for thread-unsafe hwaccels to avoid stale
233  * pointers lying around;
234  * the state was transferred to FrameThreadContext in
235  * ff_thread_finish_setup(), so nothing is leaked */
236  avctx->hwaccel = NULL;
237  avctx->hwaccel_context = NULL;
238  avctx->internal->hwaccel_priv_data = NULL;
239 
240  p->hwaccel_serializing = 0;
242  }
243  av_assert0(!avctx->hwaccel ||
245 
246  if (p->async_serializing) {
247  p->async_serializing = 0;
248 
249  async_unlock(p->parent);
250  }
251 
253 
255 
259  }
261 
262  return NULL;
263 }
264 
265 /**
266  * Update the next thread's AVCodecContext with values from the reference thread's context.
267  *
268  * @param dst The destination context.
269  * @param src The source context.
270  * @param for_user 0 if the destination is a codec thread, 1 if the destination is the user's thread
271  * @return 0 on success, negative error code on failure
272  */
273 static int update_context_from_thread(AVCodecContext *dst, const AVCodecContext *src, int for_user)
274 {
275  const FFCodec *const codec = ffcodec(dst->codec);
276  int err = 0;
277 
278  if (dst != src && (for_user || codec->update_thread_context)) {
279  dst->time_base = src->time_base;
280  dst->framerate = src->framerate;
281  dst->width = src->width;
282  dst->height = src->height;
283  dst->pix_fmt = src->pix_fmt;
284  dst->sw_pix_fmt = src->sw_pix_fmt;
285 
286  dst->coded_width = src->coded_width;
287  dst->coded_height = src->coded_height;
288 
289  dst->has_b_frames = src->has_b_frames;
290  dst->idct_algo = src->idct_algo;
291  dst->properties = src->properties;
292 
293  dst->bits_per_coded_sample = src->bits_per_coded_sample;
294  dst->sample_aspect_ratio = src->sample_aspect_ratio;
295 
296  dst->profile = src->profile;
297  dst->level = src->level;
298 
299  dst->bits_per_raw_sample = src->bits_per_raw_sample;
300 #if FF_API_TICKS_PER_FRAME
302  dst->ticks_per_frame = src->ticks_per_frame;
304 #endif
305  dst->color_primaries = src->color_primaries;
306 
307  dst->color_trc = src->color_trc;
308  dst->colorspace = src->colorspace;
309  dst->color_range = src->color_range;
310  dst->chroma_sample_location = src->chroma_sample_location;
311 
312  dst->sample_rate = src->sample_rate;
313  dst->sample_fmt = src->sample_fmt;
314  err = av_channel_layout_copy(&dst->ch_layout, &src->ch_layout);
315  if (err < 0)
316  return err;
317 
318  if (!!dst->hw_frames_ctx != !!src->hw_frames_ctx ||
319  (dst->hw_frames_ctx && dst->hw_frames_ctx->data != src->hw_frames_ctx->data)) {
321 
322  if (src->hw_frames_ctx) {
323  dst->hw_frames_ctx = av_buffer_ref(src->hw_frames_ctx);
324  if (!dst->hw_frames_ctx)
325  return AVERROR(ENOMEM);
326  }
327  }
328 
329  dst->hwaccel_flags = src->hwaccel_flags;
330 
331  ff_refstruct_replace(&dst->internal->pool, src->internal->pool);
332  }
333 
334  if (for_user) {
336  err = codec->update_thread_context_for_user(dst, src);
337  } else {
338  const PerThreadContext *p_src = src->internal->thread_ctx;
339  PerThreadContext *p_dst = dst->internal->thread_ctx;
340 
341  if (codec->update_thread_context) {
342  err = codec->update_thread_context(dst, src);
343  if (err < 0)
344  return err;
345  }
346 
347  // reset dst hwaccel state if needed
349  (!dst->hwaccel && !dst->internal->hwaccel_priv_data));
350  if (p_dst->hwaccel_threadsafe &&
351  (!p_src->hwaccel_threadsafe || dst->hwaccel != src->hwaccel)) {
352  ff_hwaccel_uninit(dst);
353  p_dst->hwaccel_threadsafe = 0;
354  }
355 
356  // propagate hwaccel state for threadsafe hwaccels
357  if (p_src->hwaccel_threadsafe) {
358  const FFHWAccel *hwaccel = ffhwaccel(src->hwaccel);
359  if (!dst->hwaccel) {
360  if (hwaccel->priv_data_size) {
361  av_assert0(hwaccel->update_thread_context);
362 
364  av_mallocz(hwaccel->priv_data_size);
365  if (!dst->internal->hwaccel_priv_data)
366  return AVERROR(ENOMEM);
367  }
368  dst->hwaccel = src->hwaccel;
369  }
370  av_assert0(dst->hwaccel == src->hwaccel);
371 
372  if (hwaccel->update_thread_context) {
373  err = hwaccel->update_thread_context(dst, src);
374  if (err < 0) {
375  av_log(dst, AV_LOG_ERROR, "Error propagating hwaccel state\n");
376  ff_hwaccel_uninit(dst);
377  return err;
378  }
379  }
380  p_dst->hwaccel_threadsafe = 1;
381  }
382  }
383 
384  return err;
385 }
386 
387 /**
388  * Update the next thread's AVCodecContext with values set by the user.
389  *
390  * @param dst The destination context.
391  * @param src The source context.
392  * @return 0 on success, negative error code on failure
393  */
395 {
396  int err;
397 
398  dst->flags = src->flags;
399 
400  dst->draw_horiz_band= src->draw_horiz_band;
401  dst->get_buffer2 = src->get_buffer2;
402 
403  dst->opaque = src->opaque;
404  dst->debug = src->debug;
405 
406  dst->slice_flags = src->slice_flags;
407  dst->flags2 = src->flags2;
408  dst->export_side_data = src->export_side_data;
409 
410  dst->skip_loop_filter = src->skip_loop_filter;
411  dst->skip_idct = src->skip_idct;
412  dst->skip_frame = src->skip_frame;
413 
414  dst->frame_num = src->frame_num;
415 
417  err = av_packet_copy_props(dst->internal->last_pkt_props, src->internal->last_pkt_props);
418  if (err < 0)
419  return err;
420 
421  return 0;
422 }
423 
424 static int submit_packet(PerThreadContext *p, AVCodecContext *user_avctx,
425  AVPacket *avpkt)
426 {
427  FrameThreadContext *fctx = p->parent;
428  PerThreadContext *prev_thread = fctx->prev_thread;
429  const AVCodec *codec = p->avctx->codec;
430  int ret;
431 
432  if (!avpkt->size && !(codec->capabilities & AV_CODEC_CAP_DELAY))
433  return 0;
434 
436 
437  ret = update_context_from_user(p->avctx, user_avctx);
438  if (ret) {
440  return ret;
441  }
443  (p->avctx->debug & FF_DEBUG_THREADS) != 0,
444  memory_order_relaxed);
445 
446  if (prev_thread) {
447  int err;
448  if (atomic_load(&prev_thread->state) == STATE_SETTING_UP) {
449  pthread_mutex_lock(&prev_thread->progress_mutex);
450  while (atomic_load(&prev_thread->state) == STATE_SETTING_UP)
451  pthread_cond_wait(&prev_thread->progress_cond, &prev_thread->progress_mutex);
452  pthread_mutex_unlock(&prev_thread->progress_mutex);
453  }
454 
455  err = update_context_from_thread(p->avctx, prev_thread->avctx, 0);
456  if (err) {
458  return err;
459  }
460  }
461 
462  /* transfer the stashed hwaccel state, if any */
464  if (!p->hwaccel_threadsafe) {
465  FFSWAP(const AVHWAccel*, p->avctx->hwaccel, fctx->stash_hwaccel);
468  }
469 
471  ret = av_packet_ref(p->avpkt, avpkt);
472  if (ret < 0) {
474  av_log(p->avctx, AV_LOG_ERROR, "av_packet_ref() failed in submit_packet()\n");
475  return ret;
476  }
477 
481 
482  fctx->prev_thread = p;
483  fctx->next_decoding++;
484 
485  return 0;
486 }
487 
489  AVFrame *picture, int *got_picture_ptr,
490  AVPacket *avpkt)
491 {
492  FrameThreadContext *fctx = avctx->internal->thread_ctx;
493  int finished = fctx->next_finished;
494  PerThreadContext *p;
495  int err;
496 
497  /* release the async lock, permitting blocked hwaccel threads to
498  * go forward while we are in this function */
499  async_unlock(fctx);
500 
501  /*
502  * Submit a packet to the next decoding thread.
503  */
504 
505  p = &fctx->threads[fctx->next_decoding];
506  err = submit_packet(p, avctx, avpkt);
507  if (err)
508  goto finish;
509 
510  /*
511  * If we're still receiving the initial packets, don't return a frame.
512  */
513 
514  if (fctx->next_decoding > (avctx->thread_count-1-(avctx->codec_id == AV_CODEC_ID_FFV1)))
515  fctx->delaying = 0;
516 
517  if (fctx->delaying) {
518  *got_picture_ptr=0;
519  if (avpkt->size) {
520  err = avpkt->size;
521  goto finish;
522  }
523  }
524 
525  /*
526  * Return the next available frame from the oldest thread.
527  * If we're at the end of the stream, then we have to skip threads that
528  * didn't output a frame/error, because we don't want to accidentally signal
529  * EOF (avpkt->size == 0 && *got_picture_ptr == 0 && err >= 0).
530  */
531 
532  do {
533  p = &fctx->threads[finished++];
534 
535  if (atomic_load(&p->state) != STATE_INPUT_READY) {
537  while (atomic_load_explicit(&p->state, memory_order_relaxed) != STATE_INPUT_READY)
540  }
541 
542  av_frame_move_ref(picture, p->frame);
543  *got_picture_ptr = p->got_frame;
544  picture->pkt_dts = p->avpkt->dts;
545  err = p->result;
546 
547  /*
548  * A later call with avkpt->size == 0 may loop over all threads,
549  * including this one, searching for a frame/error to return before being
550  * stopped by the "finished != fctx->next_finished" condition.
551  * Make sure we don't mistakenly return the same frame/error again.
552  */
553  p->got_frame = 0;
554  p->result = 0;
555 
556  if (finished >= avctx->thread_count) finished = 0;
557  } while (!avpkt->size && !*got_picture_ptr && err >= 0 && finished != fctx->next_finished);
558 
559  update_context_from_thread(avctx, p->avctx, 1);
560 
561  if (fctx->next_decoding >= avctx->thread_count) fctx->next_decoding = 0;
562 
563  fctx->next_finished = finished;
564 
565  /* return the size of the consumed packet if no error occurred */
566  if (err >= 0)
567  err = avpkt->size;
568 finish:
569  async_lock(fctx);
570  return err;
571 }
572 
574 {
575  PerThreadContext *p;
576  atomic_int *progress = f->progress ? f->progress->progress : NULL;
577 
578  if (!progress ||
579  atomic_load_explicit(&progress[field], memory_order_relaxed) >= n)
580  return;
581 
582  p = f->owner[field]->internal->thread_ctx;
583 
584  if (atomic_load_explicit(&p->debug_threads, memory_order_relaxed))
585  av_log(f->owner[field], AV_LOG_DEBUG,
586  "%p finished %d field %d\n", progress, n, field);
587 
589 
590  atomic_store_explicit(&progress[field], n, memory_order_release);
591 
594 }
595 
596 void ff_thread_await_progress(const ThreadFrame *f, int n, int field)
597 {
598  PerThreadContext *p;
599  atomic_int *progress = f->progress ? f->progress->progress : NULL;
600 
601  if (!progress ||
602  atomic_load_explicit(&progress[field], memory_order_acquire) >= n)
603  return;
604 
605  p = f->owner[field]->internal->thread_ctx;
606 
607  if (atomic_load_explicit(&p->debug_threads, memory_order_relaxed))
608  av_log(f->owner[field], AV_LOG_DEBUG,
609  "thread awaiting %d field %d from %p\n", n, field, progress);
610 
612  while (atomic_load_explicit(&progress[field], memory_order_relaxed) < n)
615 }
616 
618  PerThreadContext *p;
619 
620  if (!(avctx->active_thread_type&FF_THREAD_FRAME)) return;
621 
622  p = avctx->internal->thread_ctx;
623 
624  p->hwaccel_threadsafe = avctx->hwaccel &&
626 
627  if (hwaccel_serial(avctx) && !p->hwaccel_serializing) {
629  p->hwaccel_serializing = 1;
630  }
631 
632  /* this assumes that no hwaccel calls happen before ff_thread_finish_setup() */
633  if (avctx->hwaccel &&
635  p->async_serializing = 1;
636 
637  async_lock(p->parent);
638  }
639 
640  /* thread-unsafe hwaccels share a single private data instance, so we
641  * save hwaccel state for passing to the next thread;
642  * this is done here so that this worker thread can wipe its own hwaccel
643  * state after decoding, without requiring synchronization */
645  if (hwaccel_serial(avctx)) {
646  p->parent->stash_hwaccel = avctx->hwaccel;
649  }
650 
653  av_log(avctx, AV_LOG_WARNING, "Multiple ff_thread_finish_setup() calls\n");
654  }
655 
657 
660 }
661 
662 /// Waits for all threads to finish.
663 static void park_frame_worker_threads(FrameThreadContext *fctx, int thread_count)
664 {
665  int i;
666 
667  async_unlock(fctx);
668 
669  for (i = 0; i < thread_count; i++) {
670  PerThreadContext *p = &fctx->threads[i];
671 
672  if (atomic_load(&p->state) != STATE_INPUT_READY) {
674  while (atomic_load(&p->state) != STATE_INPUT_READY)
677  }
678  p->got_frame = 0;
679  }
680 
681  async_lock(fctx);
682 }
683 
684 #define OFF(member) offsetof(FrameThreadContext, member)
685 DEFINE_OFFSET_ARRAY(FrameThreadContext, thread_ctx, pthread_init_cnt,
686  (OFF(buffer_mutex), OFF(hwaccel_mutex), OFF(async_mutex)),
687  (OFF(async_cond)));
688 #undef OFF
689 
690 #define OFF(member) offsetof(PerThreadContext, member)
691 DEFINE_OFFSET_ARRAY(PerThreadContext, per_thread, pthread_init_cnt,
692  (OFF(progress_mutex), OFF(mutex)),
693  (OFF(input_cond), OFF(progress_cond), OFF(output_cond)));
694 #undef OFF
695 
696 void ff_frame_thread_free(AVCodecContext *avctx, int thread_count)
697 {
698  FrameThreadContext *fctx = avctx->internal->thread_ctx;
699  const FFCodec *codec = ffcodec(avctx->codec);
700  int i;
701 
702  park_frame_worker_threads(fctx, thread_count);
703 
704  for (i = 0; i < thread_count; i++) {
705  PerThreadContext *p = &fctx->threads[i];
706  AVCodecContext *ctx = p->avctx;
707 
708  if (ctx->internal) {
709  if (p->thread_init == INITIALIZED) {
711  p->die = 1;
714 
715  pthread_join(p->thread, NULL);
716  }
717  if (codec->close && p->thread_init != UNINITIALIZED)
718  codec->close(ctx);
719 
720  /* When using a threadsafe hwaccel, this is where
721  * each thread's context is uninit'd and freed. */
723 
724  if (ctx->priv_data) {
725  if (codec->p.priv_class)
728  }
729 
730  ff_refstruct_unref(&ctx->internal->pool);
731  av_packet_free(&ctx->internal->last_pkt_props);
732  av_freep(&ctx->internal);
733  av_buffer_unref(&ctx->hw_frames_ctx);
734  av_frame_side_data_free(&ctx->decoded_side_data,
735  &ctx->nb_decoded_side_data);
736  }
737 
738  av_frame_free(&p->frame);
739 
740  ff_pthread_free(p, per_thread_offsets);
741  av_packet_free(&p->avpkt);
742 
743  av_freep(&p->avctx);
744  }
745 
746  av_freep(&fctx->threads);
747  ff_pthread_free(fctx, thread_ctx_offsets);
748 
749  /* if we have stashed hwaccel state, move it to the user-facing context,
750  * so it will be freed in ff_codec_close() */
751  av_assert0(!avctx->hwaccel);
752  FFSWAP(const AVHWAccel*, avctx->hwaccel, fctx->stash_hwaccel);
753  FFSWAP(void*, avctx->hwaccel_context, fctx->stash_hwaccel_context);
754  FFSWAP(void*, avctx->internal->hwaccel_priv_data, fctx->stash_hwaccel_priv);
755 
756  av_freep(&avctx->internal->thread_ctx);
757 }
758 
759 static av_cold int init_thread(PerThreadContext *p, int *threads_to_free,
760  FrameThreadContext *fctx, AVCodecContext *avctx,
761  const FFCodec *codec, int first)
762 {
764  int err;
765 
767 
768  copy = av_memdup(avctx, sizeof(*avctx));
769  if (!copy)
770  return AVERROR(ENOMEM);
771  copy->priv_data = NULL;
772  copy->decoded_side_data = NULL;
773  copy->nb_decoded_side_data = 0;
774 
775  /* From now on, this PerThreadContext will be cleaned up by
776  * ff_frame_thread_free in case of errors. */
777  (*threads_to_free)++;
778 
779  p->parent = fctx;
780  p->avctx = copy;
781 
782  copy->internal = ff_decode_internal_alloc();
783  if (!copy->internal)
784  return AVERROR(ENOMEM);
785  copy->internal->thread_ctx = p;
786  copy->internal->progress_frame_pool = avctx->internal->progress_frame_pool;
787 
788  copy->delay = avctx->delay;
789 
790  if (codec->priv_data_size) {
791  copy->priv_data = av_mallocz(codec->priv_data_size);
792  if (!copy->priv_data)
793  return AVERROR(ENOMEM);
794 
795  if (codec->p.priv_class) {
796  *(const AVClass **)copy->priv_data = codec->p.priv_class;
797  err = av_opt_copy(copy->priv_data, avctx->priv_data);
798  if (err < 0)
799  return err;
800  }
801  }
802 
803  err = ff_pthread_init(p, per_thread_offsets);
804  if (err < 0)
805  return err;
806 
807  if (!(p->frame = av_frame_alloc()) ||
808  !(p->avpkt = av_packet_alloc()))
809  return AVERROR(ENOMEM);
810 
811  if (!first)
812  copy->internal->is_copy = 1;
813 
814  copy->internal->last_pkt_props = av_packet_alloc();
815  if (!copy->internal->last_pkt_props)
816  return AVERROR(ENOMEM);
817 
818  if (codec->init) {
819  err = codec->init(copy);
820  if (err < 0) {
823  return err;
824  }
825  }
827 
828  if (first) {
829  update_context_from_thread(avctx, copy, 1);
830 
832  for (int i = 0; i < copy->nb_decoded_side_data; i++) {
834  &avctx->nb_decoded_side_data,
835  copy->decoded_side_data[i], 0);
836  if (err < 0)
837  return err;
838  }
839  }
840 
841  atomic_init(&p->debug_threads, (copy->debug & FF_DEBUG_THREADS) != 0);
842 
844  if (err < 0)
845  return err;
847 
848  return 0;
849 }
850 
852 {
853  int thread_count = avctx->thread_count;
854  const FFCodec *codec = ffcodec(avctx->codec);
855  FrameThreadContext *fctx;
856  int err, i = 0;
857 
858  if (!thread_count) {
859  int nb_cpus = av_cpu_count();
860  // use number of cores + 1 as thread count if there is more than one
861  if (nb_cpus > 1)
862  thread_count = avctx->thread_count = FFMIN(nb_cpus + 1, MAX_AUTO_THREADS);
863  else
864  thread_count = avctx->thread_count = 1;
865  }
866 
867  if (thread_count <= 1) {
868  avctx->active_thread_type = 0;
869  return 0;
870  }
871 
872  avctx->internal->thread_ctx = fctx = av_mallocz(sizeof(FrameThreadContext));
873  if (!fctx)
874  return AVERROR(ENOMEM);
875 
876  err = ff_pthread_init(fctx, thread_ctx_offsets);
877  if (err < 0) {
878  ff_pthread_free(fctx, thread_ctx_offsets);
879  av_freep(&avctx->internal->thread_ctx);
880  return err;
881  }
882 
883  fctx->async_lock = 1;
884  fctx->delaying = 1;
885 
886  if (codec->p.type == AVMEDIA_TYPE_VIDEO)
887  avctx->delay = avctx->thread_count - 1;
888 
889  fctx->threads = av_calloc(thread_count, sizeof(*fctx->threads));
890  if (!fctx->threads) {
891  err = AVERROR(ENOMEM);
892  goto error;
893  }
894 
895  for (; i < thread_count; ) {
896  PerThreadContext *p = &fctx->threads[i];
897  int first = !i;
898 
899  err = init_thread(p, &i, fctx, avctx, codec, first);
900  if (err < 0)
901  goto error;
902  }
903 
904  return 0;
905 
906 error:
907  ff_frame_thread_free(avctx, i);
908  return err;
909 }
910 
912 {
913  int i;
914  FrameThreadContext *fctx = avctx->internal->thread_ctx;
915 
916  if (!fctx) return;
917 
919  if (fctx->prev_thread) {
920  if (fctx->prev_thread != &fctx->threads[0])
922  }
923 
924  fctx->next_decoding = fctx->next_finished = 0;
925  fctx->delaying = 1;
926  fctx->prev_thread = NULL;
927  for (i = 0; i < avctx->thread_count; i++) {
928  PerThreadContext *p = &fctx->threads[i];
929  // Make sure decode flush calls with size=0 won't return old frames
930  p->got_frame = 0;
931  av_frame_unref(p->frame);
932  p->result = 0;
933 
934  if (ffcodec(avctx->codec)->flush)
935  ffcodec(avctx->codec)->flush(p->avctx);
936  }
937 }
938 
940 {
941  if ((avctx->active_thread_type & FF_THREAD_FRAME) &&
943  PerThreadContext *p = avctx->internal->thread_ctx;
944 
945  if (atomic_load(&p->state) != STATE_SETTING_UP)
946  return 0;
947  }
948 
949  return 1;
950 }
951 
953 {
954  PerThreadContext *p;
955  int err;
956 
957  if (!(avctx->active_thread_type & FF_THREAD_FRAME))
958  return ff_get_buffer(avctx, f, flags);
959 
960  p = avctx->internal->thread_ctx;
961  if (atomic_load(&p->state) != STATE_SETTING_UP &&
963  av_log(avctx, AV_LOG_ERROR, "get_buffer() cannot be called after ff_thread_finish_setup()\n");
964  return -1;
965  }
966 
968  err = ff_get_buffer(avctx, f, flags);
969 
971 
972  return err;
973 }
974 
976 {
977  int ret = thread_get_buffer_internal(avctx, f, flags);
978  if (ret < 0)
979  av_log(avctx, AV_LOG_ERROR, "thread_get_buffer() failed\n");
980  return ret;
981 }
982 
984 {
985  int ret;
986 
987  f->owner[0] = f->owner[1] = avctx;
988  /* Hint: It is possible for this function to be called with codecs
989  * that don't support frame threading at all, namely in case
990  * a frame-threaded decoder shares code with codecs that are not.
991  * This currently affects non-MPEG-4 mpegvideo codecs.
992  * The following check will always be true for them. */
993  if (!(avctx->active_thread_type & FF_THREAD_FRAME))
994  return ff_get_buffer(avctx, f->f, flags);
995 
996  f->progress = ff_refstruct_allocz(sizeof(*f->progress));
997  if (!f->progress)
998  return AVERROR(ENOMEM);
999 
1000  atomic_init(&f->progress->progress[0], -1);
1001  atomic_init(&f->progress->progress[1], -1);
1002 
1003  ret = ff_thread_get_buffer(avctx, f->f, flags);
1004  if (ret)
1005  ff_refstruct_unref(&f->progress);
1006  return ret;
1007 }
1008 
1010 {
1011  ff_refstruct_unref(&f->progress);
1012  f->owner[0] = f->owner[1] = NULL;
1013  if (f->f)
1014  av_frame_unref(f->f);
1015 }
1016 
1018 {
1019  PerThreadContext *p;
1020  const void *ref;
1021 
1022  if (!avctx->internal->is_copy)
1023  return avctx->active_thread_type & FF_THREAD_FRAME ?
1025 
1026  p = avctx->internal->thread_ctx;
1027 
1028  av_assert1(memcpy(&ref, (char*)avctx->priv_data + offset, sizeof(ref)) && ref == NULL);
1029 
1030  memcpy(&ref, (const char*)p->parent->threads[0].avctx->priv_data + offset, sizeof(ref));
1031  av_assert1(ref);
1032  ff_refstruct_replace((char*)avctx->priv_data + offset, ref);
1033 
1034  return FF_THREAD_IS_COPY;
1035 }
error
static void error(const char *err)
Definition: target_bsf_fuzzer.c:32
pthread_mutex_t
_fmutex pthread_mutex_t
Definition: os2threads.h:53
hwconfig.h
FFCodec::update_thread_context
int(* update_thread_context)(struct AVCodecContext *dst, const struct AVCodecContext *src)
Copy necessary context variables from a previous thread context to the current one.
Definition: codec_internal.h:156
av_packet_unref
void av_packet_unref(AVPacket *pkt)
Wipe the packet.
Definition: packet.c:427
AVCodecContext::hwaccel
const struct AVHWAccel * hwaccel
Hardware accelerator in use.
Definition: avcodec.h:1427
AVCodec
AVCodec.
Definition: codec.h:187
UNINITIALIZED
@ UNINITIALIZED
Thread has not been created, AVCodec->close mustn't be called.
Definition: pthread_frame.c:64
FF_ENABLE_DEPRECATION_WARNINGS
#define FF_ENABLE_DEPRECATION_WARNINGS
Definition: internal.h:73
thread_set_name
static void thread_set_name(PerThreadContext *p)
Definition: pthread_frame.c:170
AVCodecContext::hwaccel_context
void * hwaccel_context
Legacy hardware accelerator context.
Definition: avcodec.h:1451
pthread_join
static av_always_inline int pthread_join(pthread_t thread, void **value_ptr)
Definition: os2threads.h:94
AV_LOG_WARNING
#define AV_LOG_WARNING
Something somehow does not look correct.
Definition: log.h:186
name
it s the only field you need to keep assuming you have a context There is some magic you don t need to care about around this just let it vf default minimum maximum flags name is the option name
Definition: writing_filters.txt:88
PerThreadContext::input_cond
pthread_cond_t input_cond
Used to wait for a new packet from the main thread.
Definition: pthread_frame.c:82
atomic_store
#define atomic_store(object, desired)
Definition: stdatomic.h:85
FF_CODEC_CAP_INIT_CLEANUP
#define FF_CODEC_CAP_INIT_CLEANUP
The codec allows calling the close function for deallocation even if the init function returned a fai...
Definition: codec_internal.h:42
AVERROR
Filter the word “frame” indicates either a video frame or a group of audio as stored in an AVFrame structure Format for each input and each output the list of supported formats For video that means pixel format For audio that means channel sample they are references to shared objects When the negotiation mechanism computes the intersection of the formats supported at each end of a all references to both lists are replaced with a reference to the intersection And when a single format is eventually chosen for a link amongst the remaining all references to the list are updated That means that if a filter requires that its input and output have the same format amongst a supported all it has to do is use a reference to the same list of formats query_formats can leave some formats unset and return AVERROR(EAGAIN) to cause the negotiation mechanism toagain later. That can be used by filters with complex requirements to use the format negotiated on one link to set the formats supported on another. Frame references ownership and permissions
opt.h
hwaccel_serial
static int hwaccel_serial(const AVCodecContext *avctx)
Definition: pthread_frame.c:147
AVCodecContext::colorspace
enum AVColorSpace colorspace
YUV colorspace type.
Definition: avcodec.h:685
AVCodecContext::decoded_side_data
AVFrameSideData ** decoded_side_data
Array containing static side data, such as HDR10 CLL / MDCV structures.
Definition: avcodec.h:2076
AVCodecContext::sample_rate
int sample_rate
samples per second
Definition: avcodec.h:1050
PerThreadContext::debug_threads
atomic_int debug_threads
Set if the FF_DEBUG_THREADS option is set.
Definition: pthread_frame.c:110
AVCodec::priv_class
const AVClass * priv_class
AVClass for the private context.
Definition: codec.h:212
FrameThreadContext::next_decoding
int next_decoding
The next context to submit a packet to.
Definition: pthread_frame.c:131
thread.h
AVBufferRef::data
uint8_t * data
The data buffer.
Definition: buffer.h:90
ThreadFrameProgress
Definition: pthread_frame.c:69
ff_thread_flush
void ff_thread_flush(AVCodecContext *avctx)
Wait for decoding threads to finish and reset internal state.
Definition: pthread_frame.c:911
init_thread
static av_cold int init_thread(PerThreadContext *p, int *threads_to_free, FrameThreadContext *fctx, AVCodecContext *avctx, const FFCodec *codec, int first)
Definition: pthread_frame.c:759
ff_thread_can_start_frame
int ff_thread_can_start_frame(AVCodecContext *avctx)
Definition: pthread_frame.c:939
MAX_AUTO_THREADS
#define MAX_AUTO_THREADS
Definition: pthread_internal.h:26
PerThreadContext::state
atomic_int state
Definition: pthread_frame.c:97
FF_THREAD_IS_FIRST_THREAD
@ FF_THREAD_IS_FIRST_THREAD
Definition: thread.h:89
FrameThreadContext
Context stored in the client AVCodecInternal thread_ctx.
Definition: pthread_frame.c:116
av_frame_free
void av_frame_free(AVFrame **frame)
Free the frame and any dynamically allocated objects in it, e.g.
Definition: frame.c:160
park_frame_worker_threads
static void park_frame_worker_threads(FrameThreadContext *fctx, int thread_count)
Waits for all threads to finish.
Definition: pthread_frame.c:663
AVFrame
This structure describes decoded (raw) audio or video data.
Definition: frame.h:374
AVCodecContext::color_trc
enum AVColorTransferCharacteristic color_trc
Color Transfer Characteristic.
Definition: avcodec.h:678
AVCodec::capabilities
int capabilities
Codec capabilities.
Definition: codec.h:206
internal.h
ff_thread_sync_ref
enum ThreadingStatus ff_thread_sync_ref(AVCodecContext *avctx, size_t offset)
Allows to synchronize objects whose lifetime is the whole decoding process among all frame threads.
Definition: pthread_frame.c:1017
STATE_SETUP_FINISHED
@ STATE_SETUP_FINISHED
Set after the codec has called ff_thread_finish_setup().
Definition: pthread_frame.c:60
version_major.h
atomic_int
intptr_t atomic_int
Definition: stdatomic.h:55
FFCodec
Definition: codec_internal.h:126
INITIALIZED
@ INITIALIZED
Thread has been properly set up.
Definition: pthread_frame.c:66
av_buffer_ref
AVBufferRef * av_buffer_ref(const AVBufferRef *buf)
Create a new reference to an AVBuffer.
Definition: buffer.c:103
av_frame_side_data_clone
int av_frame_side_data_clone(AVFrameSideData ***sd, int *nb_sd, const AVFrameSideData *src, unsigned int flags)
Add a new side data entry to an array based on existing side data, taking a reference towards the con...
Definition: frame.c:872
AVFrame::buf
AVBufferRef * buf[AV_NUM_DATA_POINTERS]
AVBuffer references backing the data for this frame.
Definition: frame.h:587
FrameThreadContext::stash_hwaccel_context
void * stash_hwaccel_context
Definition: pthread_frame.c:143
AVCodecContext::delay
int delay
Codec delay.
Definition: avcodec.h:601
PerThreadContext::die
int die
Set when the thread should exit.
Definition: pthread_frame.c:99
thread.h
ff_pthread_free
av_cold void ff_pthread_free(void *obj, const unsigned offsets[])
Definition: pthread.c:91
FrameThreadContext::next_finished
int next_finished
The next context to return output from.
Definition: pthread_frame.c:132
av_packet_free
void av_packet_free(AVPacket **pkt)
Free the packet, if the packet is reference counted, it will be unreferenced first.
Definition: packet.c:74
FrameThreadContext::buffer_mutex
pthread_mutex_t buffer_mutex
Mutex used to protect get/release_buffer().
Definition: pthread_frame.c:121
ff_hwaccel_uninit
void ff_hwaccel_uninit(AVCodecContext *avctx)
Definition: decode.c:1210
av_memdup
void * av_memdup(const void *p, size_t size)
Duplicate a buffer with av_malloc().
Definition: mem.c:304
FFCodec::priv_data_size
int priv_data_size
Definition: codec_internal.h:144
AVCodecContext::framerate
AVRational framerate
Definition: avcodec.h:560
AVCodecInternal::is_copy
int is_copy
When using frame-threaded decoding, this field is set for the first worker thread (e....
Definition: internal.h:54
AVCodecInternal::progress_frame_pool
struct FFRefStructPool * progress_frame_pool
Definition: internal.h:64
ff_frame_thread_free
void ff_frame_thread_free(AVCodecContext *avctx, int thread_count)
Definition: pthread_frame.c:696
AVHWAccel
Definition: avcodec.h:2088
AVCodecContext::skip_idct
enum AVDiscard skip_idct
Skip IDCT/dequantization for selected frames.
Definition: avcodec.h:1812
FFCodec::p
AVCodec p
The public AVCodec.
Definition: codec_internal.h:130
finish
static void finish(void)
Definition: movenc.c:373
FFHWAccel
Definition: hwaccel_internal.h:34
AVCodecContext::codec
const struct AVCodec * codec
Definition: avcodec.h:454
AVCodecContext::ch_layout
AVChannelLayout ch_layout
Audio channel layout.
Definition: avcodec.h:1065
AVCodecContext::skip_frame
enum AVDiscard skip_frame
Skip decoding for selected frames.
Definition: avcodec.h:1819
AVCodecContext::thread_count
int thread_count
thread count is used to decide how many independent tasks should be passed to execute()
Definition: avcodec.h:1582
update_context_from_user
static int update_context_from_user(AVCodecContext *dst, const AVCodecContext *src)
Update the next thread's AVCodecContext with values set by the user.
Definition: pthread_frame.c:394
FrameThreadContext::pthread_init_cnt
unsigned pthread_init_cnt
Number of successfully initialized mutexes/conditions.
Definition: pthread_frame.c:120
av_opt_free
void av_opt_free(void *obj)
Free all allocated objects in obj.
Definition: opt.c:1910
HWACCEL_CAP_THREAD_SAFE
#define HWACCEL_CAP_THREAD_SAFE
Definition: hwaccel_internal.h:32
AVCodecContext::flags
int flags
AV_CODEC_FLAG_*.
Definition: avcodec.h:502
PerThreadContext
Context used by codec threads and stored in their AVCodecInternal thread_ctx.
Definition: pthread_frame.c:76
AVCodecContext::coded_height
int coded_height
Definition: avcodec.h:633
submit_packet
static int submit_packet(PerThreadContext *p, AVCodecContext *user_avctx, AVPacket *avpkt)
Definition: pthread_frame.c:424
refstruct.h
av_frame_alloc
AVFrame * av_frame_alloc(void)
Allocate an AVFrame and set its fields to default values.
Definition: frame.c:148
AVCodecContext::get_buffer2
int(* get_buffer2)(struct AVCodecContext *s, AVFrame *frame, int flags)
This callback is called at the beginning of each frame to get data buffer(s) for it.
Definition: avcodec.h:1222
first
trying all byte sequences megabyte in length and selecting the best looking sequence will yield cases to try But first
Definition: rate_distortion.txt:12
avassert.h
AVCodecContext::color_primaries
enum AVColorPrimaries color_primaries
Chromaticity coordinates of the source primaries.
Definition: avcodec.h:671
AV_LOG_ERROR
#define AV_LOG_ERROR
Something went wrong and cannot losslessly be recovered.
Definition: log.h:180
av_cold
#define av_cold
Definition: attributes.h:90
ff_thread_report_progress
void ff_thread_report_progress(ThreadFrame *f, int n, int field)
Notify later decoding threads when part of their reference picture is ready.
Definition: pthread_frame.c:573
NEEDS_CLOSE
@ NEEDS_CLOSE
FFCodec->close needs to be called.
Definition: pthread_frame.c:65
FFCodec::update_thread_context_for_user
int(* update_thread_context_for_user)(struct AVCodecContext *dst, const struct AVCodecContext *src)
Copy variables back to the user-facing context.
Definition: codec_internal.h:161
AVCodecContext::has_b_frames
int has_b_frames
Size of the frame reordering buffer in the decoder.
Definition: avcodec.h:723
FrameThreadContext::async_lock
int async_lock
Definition: pthread_frame.c:129
AVCodecInternal::pool
struct FramePool * pool
Definition: internal.h:62
AVCodecContext::nb_decoded_side_data
int nb_decoded_side_data
Definition: avcodec.h:2077
PerThreadContext::output_cond
pthread_cond_t output_cond
Used by the main thread to wait for frames to finish.
Definition: pthread_frame.c:84
ff_thread_get_buffer
int ff_thread_get_buffer(AVCodecContext *avctx, AVFrame *f, int flags)
Wrapper around get_buffer() for frame-multithreaded codecs.
Definition: pthread_frame.c:975
av_assert0
#define av_assert0(cond)
assert() equivalent, that is always enabled.
Definition: avassert.h:40
AVCodecContext::bits_per_raw_sample
int bits_per_raw_sample
Bits per sample/pixel of internal libavcodec pixel/sample format.
Definition: avcodec.h:1574
AV_LOG_DEBUG
#define AV_LOG_DEBUG
Stuff which is only useful for libav* developers.
Definition: log.h:201
ctx
AVFormatContext * ctx
Definition: movenc.c:49
FFCodec::flush
void(* flush)(struct AVCodecContext *)
Flush buffers.
Definition: codec_internal.h:245
decode.h
PerThreadContext::hwaccel_threadsafe
int hwaccel_threadsafe
Definition: pthread_frame.c:108
field
it s the only field you need to keep assuming you have a context There is some magic you don t need to care about around this field
Definition: writing_filters.txt:78
atomic_load
#define atomic_load(object)
Definition: stdatomic.h:93
pthread_cond_broadcast
static av_always_inline int pthread_cond_broadcast(pthread_cond_t *cond)
Definition: os2threads.h:162
FrameThreadContext::prev_thread
PerThreadContext * prev_thread
The last thread submit_packet() was called on.
Definition: pthread_frame.c:118
FFCodec::decode
int(* decode)(struct AVCodecContext *avctx, struct AVFrame *frame, int *got_frame_ptr, struct AVPacket *avpkt)
Decode to an AVFrame.
Definition: codec_internal.h:192
FFCodec::init
int(* init)(struct AVCodecContext *)
Definition: codec_internal.h:177
AVCodecContext::codec_id
enum AVCodecID codec_id
Definition: avcodec.h:455
arg
const char * arg
Definition: jacosubdec.c:67
pthread_create
static av_always_inline int pthread_create(pthread_t *thread, const pthread_attr_t *attr, void *(*start_routine)(void *), void *arg)
Definition: os2threads.h:80
PerThreadContext::got_frame
int got_frame
The output of got_picture_ptr from the last avcodec_decode_video() call.
Definition: pthread_frame.c:94
threadframe.h
HWACCEL_CAP_ASYNC_SAFE
#define HWACCEL_CAP_ASYNC_SAFE
Header providing the internals of AVHWAccel.
Definition: hwaccel_internal.h:31
AVClass
Describe the class of an AVClass context structure.
Definition: log.h:66
NULL
#define NULL
Definition: coverity.c:32
AVCodecContext::color_range
enum AVColorRange color_range
MPEG vs JPEG YUV range.
Definition: avcodec.h:695
av_buffer_unref
void av_buffer_unref(AVBufferRef **buf)
Free a given reference and automatically free the buffer if there are no more references to it.
Definition: buffer.c:139
hwaccel_internal.h
ff_thread_await_progress
void ff_thread_await_progress(const ThreadFrame *f, int n, int field)
Wait for earlier decoding threads to finish reference pictures.
Definition: pthread_frame.c:596
AVCodecContext::slice_flags
int slice_flags
slice flags
Definition: avcodec.h:730
thread_get_buffer_internal
static int thread_get_buffer_internal(AVCodecContext *avctx, AVFrame *f, int flags)
Definition: pthread_frame.c:952
AVCodec::type
enum AVMediaType type
Definition: codec.h:200
frame_worker_thread
static attribute_align_arg void * frame_worker_thread(void *arg)
Codec worker thread.
Definition: pthread_frame.c:188
AVCodecContext::internal
struct AVCodecInternal * internal
Private context used for internal data.
Definition: avcodec.h:480
PerThreadContext::progress_mutex
pthread_mutex_t progress_mutex
Mutex used to protect frame progress values and progress_cond.
Definition: pthread_frame.c:87
FrameThreadContext::async_mutex
pthread_mutex_t async_mutex
Definition: pthread_frame.c:127
ff_thread_finish_setup
void ff_thread_finish_setup(AVCodecContext *avctx)
If the codec defines update_thread_context(), call this when they are ready for the next thread to st...
Definition: pthread_frame.c:617
ff_thread_release_ext_buffer
void ff_thread_release_ext_buffer(ThreadFrame *f)
Unref a ThreadFrame.
Definition: pthread_frame.c:1009
FrameThreadContext::hwaccel_mutex
pthread_mutex_t hwaccel_mutex
This lock is used for ensuring threads run in serial when thread-unsafe hwaccel is used.
Definition: pthread_frame.c:126
PerThreadContext::avctx
AVCodecContext * avctx
Context used to decode packets passed to this thread.
Definition: pthread_frame.c:89
ff_refstruct_allocz
static void * ff_refstruct_allocz(size_t size)
Equivalent to ff_refstruct_alloc_ext(size, 0, NULL, NULL)
Definition: refstruct.h:105
pthread_internal.h
AVFrame::pkt_dts
int64_t pkt_dts
DTS copied from the AVPacket that triggered returning this frame.
Definition: frame.h:493
FF_THREAD_IS_COPY
@ FF_THREAD_IS_COPY
Definition: thread.h:88
av_packet_ref
int av_packet_ref(AVPacket *dst, const AVPacket *src)
Setup a new reference to the data described by a given packet.
Definition: packet.c:435
AVCodecContext::level
int level
Encoding level descriptor.
Definition: avcodec.h:1783
atomic_load_explicit
#define atomic_load_explicit(object, order)
Definition: stdatomic.h:96
FF_DEBUG_THREADS
#define FF_DEBUG_THREADS
Definition: avcodec.h:1409
OFF
#define OFF(member)
Definition: pthread_frame.c:690
pthread_mutex_unlock
#define pthread_mutex_unlock(a)
Definition: ffprobe.c:82
AVCodecInternal::last_pkt_props
AVPacket * last_pkt_props
Properties (timestamps+side data) extracted from the last packet passed for decoding.
Definition: internal.h:83
async_lock
static void async_lock(FrameThreadContext *fctx)
Definition: pthread_frame.c:152
av_opt_copy
int av_opt_copy(void *dst, const void *src)
Copy options from src object into dest object.
Definition: opt.c:2110
PerThreadContext::pthread_init_cnt
unsigned pthread_init_cnt
Number of successfully initialized mutexes/conditions.
Definition: pthread_frame.c:81
PerThreadContext::thread
pthread_t thread
Definition: pthread_frame.c:79
av_cpu_count
int av_cpu_count(void)
Definition: cpu.c:209
attribute_align_arg
#define attribute_align_arg
Definition: internal.h:50
AVCodecContext::time_base
AVRational time_base
This is the fundamental unit of time (in seconds) in terms of which frame timestamps are represented.
Definition: avcodec.h:544
PerThreadContext::result
int result
The result of the last codec decode/encode() call.
Definition: pthread_frame.c:95
FrameThreadContext::stash_hwaccel
const AVHWAccel * stash_hwaccel
Definition: pthread_frame.c:142
AV_CODEC_ID_FFV1
@ AV_CODEC_ID_FFV1
Definition: codec_id.h:85
f
f
Definition: af_crystalizer.c:121
AVCodecContext::flags2
int flags2
AV_CODEC_FLAG2_*.
Definition: avcodec.h:509
ff_get_buffer
int ff_get_buffer(AVCodecContext *avctx, AVFrame *frame, int flags)
Get a buffer for a frame.
Definition: decode.c:1556
AVPacket::size
int size
Definition: packet.h:525
ff_thread_decode_frame
int ff_thread_decode_frame(AVCodecContext *avctx, AVFrame *picture, int *got_picture_ptr, AVPacket *avpkt)
Submit a new frame to a decoding thread.
Definition: pthread_frame.c:488
copy
static void copy(const float *p1, float *p2, const int length)
Definition: vf_vaguedenoiser.c:186
codec_internal.h
AVCodecInternal::hwaccel_priv_data
void * hwaccel_priv_data
hwaccel-specific private data
Definition: internal.h:123
cpu.h
PerThreadContext::avpkt
AVPacket * avpkt
Input packet (for decoding) or output (for encoding).
Definition: pthread_frame.c:91
async_unlock
static void async_unlock(FrameThreadContext *fctx)
Definition: pthread_frame.c:161
AVCodecContext::sample_fmt
enum AVSampleFormat sample_fmt
audio sample format
Definition: avcodec.h:1057
FrameThreadContext::async_cond
pthread_cond_t async_cond
Definition: pthread_frame.c:128
ffcodec
static const av_always_inline FFCodec * ffcodec(const AVCodec *codec)
Definition: codec_internal.h:305
frame.h
buffer.h
AVPacket::dts
int64_t dts
Decompression timestamp in AVStream->time_base units; the time at which the packet is decompressed.
Definition: packet.h:523
PerThreadContext::parent
struct FrameThreadContext * parent
Definition: pthread_frame.c:77
offset
it s the only field you need to keep assuming you have a context There is some magic you don t need to care about around this just let it vf offset
Definition: writing_filters.txt:86
av_packet_alloc
AVPacket * av_packet_alloc(void)
Allocate an AVPacket and set its fields to default values.
Definition: packet.c:63
AVCodecContext::skip_loop_filter
enum AVDiscard skip_loop_filter
Skip loop filtering for selected frames.
Definition: avcodec.h:1805
FF_THREAD_NO_FRAME_THREADING
@ FF_THREAD_NO_FRAME_THREADING
Definition: thread.h:90
pthread_t
Definition: os2threads.h:44
FF_THREAD_FRAME
#define FF_THREAD_FRAME
Decode more than one frame at once.
Definition: avcodec.h:1593
AVCodecContext::bits_per_coded_sample
int bits_per_coded_sample
bits per sample/pixel from the demuxer (needed for huffyuv).
Definition: avcodec.h:1567
FFCodec::caps_internal
unsigned caps_internal
Internal codec capabilities FF_CODEC_CAP_*.
Definition: codec_internal.h:135
av_packet_copy_props
int av_packet_copy_props(AVPacket *dst, const AVPacket *src)
Copy only "properties" fields from src to dst.
Definition: packet.c:390
PerThreadContext::thread_init
int thread_init
Definition: pthread_frame.c:80
FFCodec::cb
union FFCodec::@79 cb
log.h
i
#define i(width, name, range_min, range_max)
Definition: cbs_h2645.c:256
AVCodecContext::properties
unsigned properties
Properties of the stream that gets decoded.
Definition: avcodec.h:1795
av_frame_side_data_free
void av_frame_side_data_free(AVFrameSideData ***sd, int *nb_sd)
Free all side data entries and their contents, then zeroes out the values which the pointers are poin...
Definition: frame.c:111
internal.h
STATE_SETTING_UP
@ STATE_SETTING_UP
Set before the codec has called ff_thread_finish_setup().
Definition: pthread_frame.c:58
common.h
AVCodecContext::hwaccel_flags
int hwaccel_flags
Bit set of AV_HWACCEL_FLAG_* flags, which affect hardware accelerated decoding (if active).
Definition: avcodec.h:1506
av_assert1
#define av_assert1(cond)
assert() equivalent, that does not lie in speed critical code.
Definition: avassert.h:56
atomic_store_explicit
#define atomic_store_explicit(object, desired, order)
Definition: stdatomic.h:90
FFMIN
#define FFMIN(a, b)
Definition: macros.h:49
av_frame_move_ref
void av_frame_move_ref(AVFrame *dst, AVFrame *src)
Move everything contained in src to dst and reset src.
Definition: frame.c:633
av_frame_unref
void av_frame_unref(AVFrame *frame)
Unreference all the buffers referenced by frame and reset the frame fields.
Definition: frame.c:606
av_mallocz
void * av_mallocz(size_t size)
Allocate a memory block with alignment suitable for all memory accesses (including vectors if availab...
Definition: mem.c:256
AVCodecContext::idct_algo
int idct_algo
IDCT algorithm, see FF_IDCT_* below.
Definition: avcodec.h:1547
AVCodec::name
const char * name
Name of the codec implementation.
Definition: codec.h:194
AVCodecContext::chroma_sample_location
enum AVChromaLocation chroma_sample_location
This defines the location of chroma samples.
Definition: avcodec.h:702
pthread_cond_t
Definition: os2threads.h:58
AVCodecContext::height
int height
Definition: avcodec.h:618
AVCodecContext::pix_fmt
enum AVPixelFormat pix_fmt
Pixel format, see AV_PIX_FMT_xxx.
Definition: avcodec.h:657
ff_thread_get_ext_buffer
int ff_thread_get_ext_buffer(AVCodecContext *avctx, ThreadFrame *f, int flags)
Wrapper around ff_get_buffer() for frame-multithreaded codecs.
Definition: pthread_frame.c:983
av_calloc
void * av_calloc(size_t nmemb, size_t size)
Definition: mem.c:264
STATE_INPUT_READY
@ STATE_INPUT_READY
Set when the thread is awaiting a packet.
Definition: pthread_frame.c:56
AVCodecContext::hw_frames_ctx
AVBufferRef * hw_frames_ctx
A reference to the AVHWFramesContext describing the input (for encoding) or output (decoding) frames.
Definition: avcodec.h:1475
avcodec.h
AVCodecContext::frame_num
int64_t frame_num
Frame counter, set by libavcodec.
Definition: avcodec.h:2030
DEFINE_OFFSET_ARRAY
DEFINE_OFFSET_ARRAY(FrameThreadContext, thread_ctx, pthread_init_cnt,(OFF(buffer_mutex), OFF(hwaccel_mutex), OFF(async_mutex)),(OFF(async_cond)))
ret
ret
Definition: filter_design.txt:187
FFSWAP
#define FFSWAP(type, a, b)
Definition: macros.h:52
ff_frame_thread_init
int ff_frame_thread_init(AVCodecContext *avctx)
Definition: pthread_frame.c:851
ff_decode_internal_alloc
struct AVCodecInternal * ff_decode_internal_alloc(void)
Definition: decode.c:2131
PerThreadContext::async_serializing
int async_serializing
Definition: pthread_frame.c:102
AVCodecContext::opaque
void * opaque
Private data of the user, can be used to carry app specific stuff.
Definition: avcodec.h:487
hwaccel
static const char * hwaccel
Definition: ffplay.c:353
ff_refstruct_replace
void ff_refstruct_replace(void *dstp, const void *src)
Ensure *dstp refers to the same object as src.
Definition: refstruct.c:160
pthread_cond_signal
static av_always_inline int pthread_cond_signal(pthread_cond_t *cond)
Definition: os2threads.h:152
AVCodecContext::draw_horiz_band
void(* draw_horiz_band)(struct AVCodecContext *s, const AVFrame *src, int offset[AV_NUM_DATA_POINTERS], int y, int type, int height)
If non NULL, 'draw_horiz_band' is called by the libavcodec decoder to draw a horizontal band.
Definition: avcodec.h:758
AVCodecContext
main external API structure.
Definition: avcodec.h:445
AVCodecContext::active_thread_type
int active_thread_type
Which multithreading methods are in use by the codec.
Definition: avcodec.h:1601
PerThreadContext::hwaccel_serializing
int hwaccel_serializing
Definition: pthread_frame.c:101
ThreadFrame
Definition: threadframe.h:27
avcodec_internal.h
PerThreadContext::frame
AVFrame * frame
Output frame (for decoding) or input (for encoding).
Definition: pthread_frame.c:93
AVCodecContext::profile
int profile
profile
Definition: avcodec.h:1639
ffhwaccel
static const FFHWAccel * ffhwaccel(const AVHWAccel *codec)
Definition: hwaccel_internal.h:166
ref
static int ref[MAX_W *MAX_W]
Definition: jpeg2000dwt.c:112
AVCodecContext::ticks_per_frame
attribute_deprecated int ticks_per_frame
For some codecs, the time base is closer to the field rate than the frame rate.
Definition: avcodec.h:576
AVCodecContext::export_side_data
int export_side_data
Bit set of AV_CODEC_EXPORT_DATA_* flags, which affects the kind of metadata exported in frame,...
Definition: avcodec.h:1926
AV_CODEC_CAP_DELAY
#define AV_CODEC_CAP_DELAY
Encoder or decoder requires flushing with NULL input at the end in order to give the complete and cor...
Definition: codec.h:76
FFCodec::close
int(* close)(struct AVCodecContext *)
Definition: codec_internal.h:239
ff_pthread_init
av_cold int ff_pthread_init(void *obj, const unsigned offsets[])
Initialize/destroy a list of mutexes/conditions contained in a structure.
Definition: pthread.c:104
pthread_cond_wait
static av_always_inline int pthread_cond_wait(pthread_cond_t *cond, pthread_mutex_t *mutex)
Definition: os2threads.h:192
AVCodecContext::debug
int debug
debug
Definition: avcodec.h:1396
av_channel_layout_copy
int av_channel_layout_copy(AVChannelLayout *dst, const AVChannelLayout *src)
Make a copy of a channel layout.
Definition: channel_layout.c:440
FF_DISABLE_DEPRECATION_WARNINGS
#define FF_DISABLE_DEPRECATION_WARNINGS
Definition: internal.h:72
AVCodecContext::coded_width
int coded_width
Bitstream width / height, may be different from width/height e.g.
Definition: avcodec.h:633
AVMEDIA_TYPE_VIDEO
@ AVMEDIA_TYPE_VIDEO
Definition: avutil.h:201
FrameThreadContext::delaying
int delaying
Set for the first N packets, where N is the number of threads.
Definition: pthread_frame.c:134
mem.h
ThreadingStatus
ThreadingStatus
Definition: thread.h:87
AVCodecContext::priv_data
void * priv_data
Definition: avcodec.h:472
AVPacket
This structure stores compressed data.
Definition: packet.h:501
av_freep
#define av_freep(p)
Definition: tableprint_vlc.h:34
src
INIT_CLIP pixel * src
Definition: h264pred_template.c:418
AVCodecInternal::thread_ctx
void * thread_ctx
Definition: internal.h:66
AVCodecContext::width
int width
picture width / height.
Definition: avcodec.h:618
flags
#define flags(name, subs,...)
Definition: cbs_av1.c:474
PerThreadContext::mutex
pthread_mutex_t mutex
Mutex used to protect the contents of the PerThreadContext.
Definition: pthread_frame.c:86
av_log
#define av_log(a,...)
Definition: tableprint_vlc.h:27
update_context_from_thread
static int update_context_from_thread(AVCodecContext *dst, const AVCodecContext *src, int for_user)
Update the next thread's AVCodecContext with values from the reference thread's context.
Definition: pthread_frame.c:273
AVCodecContext::sw_pix_fmt
enum AVPixelFormat sw_pix_fmt
Nominal unaccelerated pixel format, see AV_PIX_FMT_xxx.
Definition: avcodec.h:664
atomic_init
#define atomic_init(obj, value)
Definition: stdatomic.h:33
FFHWAccel::caps_internal
int caps_internal
Internal hwaccel capabilities.
Definition: hwaccel_internal.h:117
snprintf
#define snprintf
Definition: snprintf.h:34
AVFormatContext::priv_data
void * priv_data
Format private data.
Definition: avformat.h:1283
ff_refstruct_unref
void ff_refstruct_unref(void *objp)
Decrement the reference count of the underlying object and automatically free the object if there are...
Definition: refstruct.c:120
AVCodecContext::sample_aspect_ratio
AVRational sample_aspect_ratio
sample aspect ratio (0 if unknown) That is the width of a pixel divided by the height of the pixel.
Definition: avcodec.h:642
ThreadFrameProgress::progress
atomic_int progress[2]
Definition: pthread_frame.c:70
FrameThreadContext::stash_hwaccel_priv
void * stash_hwaccel_priv
Definition: pthread_frame.c:144
mutex
static AVMutex mutex
Definition: log.c:46
PerThreadContext::progress_cond
pthread_cond_t progress_cond
Used by child threads to wait for progress to change.
Definition: pthread_frame.c:83
FrameThreadContext::threads
PerThreadContext * threads
The contexts for each thread.
Definition: pthread_frame.c:117
pthread_mutex_lock
#define pthread_mutex_lock(a)
Definition: ffprobe.c:78
ff_thread_setname
static int ff_thread_setname(const char *name)
Definition: thread.h:216