]> git.sesse.net Git - ffmpeg/commitdiff
Merge remote-tracking branch 'qatar/master'
authorMichael Niedermayer <michaelni@gmx.at>
Mon, 2 Jan 2012 01:48:34 +0000 (02:48 +0100)
committerMichael Niedermayer <michaelni@gmx.at>
Mon, 2 Jan 2012 02:10:30 +0000 (03:10 +0100)
* qatar/master:
  avconv: make -frames work for all types of streams, not just video.
  bfi: K&R cosmetics
  bgmc: K&R cleanup
  rawdec: Set start_time to 0 for raw audio files.
  Detect 'yuv2' as rawvideo also in avi.
  rawdec: propagate pict_type information to the output frame
  rawdec: Support more QT 1bpp rawvideo files.
  avconv: free bitstream filters
  threads: limit the number of automatic threads to MAX_AUTO_THREADS
  avplay: K&R cleanup
  fate: use rgb24 as output format for dfa tests
  threads: set thread_count to 1 when thread support is disabled
  threads: introduce CODEC_CAP_AUTO_THREADS and add it to libx264

Conflicts:
ffplay.c
libavcodec/avcodec.h
libavcodec/pthread.c
libavcodec/version.h
tests/ref/fate/dfa1
tests/ref/fate/dfa10
tests/ref/fate/dfa11
tests/ref/fate/dfa2
tests/ref/fate/dfa3
tests/ref/fate/dfa4
tests/ref/fate/dfa5
tests/ref/fate/dfa6
tests/ref/fate/dfa7
tests/ref/fate/dfa8
tests/ref/fate/dfa9

Merged-by: Michael Niedermayer <michaelni@gmx.at>
21 files changed:
1  2 
avconv.c
ffmpeg.c
ffplay.c
libavcodec/avcodec.h
libavcodec/bfi.c
libavcodec/bgmc.c
libavcodec/libx264.c
libavcodec/pthread.c
libavcodec/utils.c
libavcodec/version.h
tests/ref/fate/dfa1
tests/ref/fate/dfa10
tests/ref/fate/dfa11
tests/ref/fate/dfa2
tests/ref/fate/dfa3
tests/ref/fate/dfa4
tests/ref/fate/dfa5
tests/ref/fate/dfa6
tests/ref/fate/dfa7
tests/ref/fate/dfa8
tests/ref/fate/dfa9

diff --cc avconv.c
index 6f036dac4187e2b0fb5ac6cb2c9b06dec988ddf1,159c7b540612bd2dbed5b82ff1c79f208c85b9b1..d4ffcb07654efe3f8bc2d61118809f28311965e0
+++ b/avconv.c
@@@ -1823,17 -1764,9 +1834,16 @@@ static void do_streamcopy(InputStream *
          opkt.data = pkt->data;
          opkt.size = pkt->size;
      }
 +    if (of->ctx->oformat->flags & AVFMT_RAWPICTURE) {
 +        /* store AVPicture in AVPacket, as expected by the output format */
 +        avpicture_fill(&pict, opkt.data, ost->st->codec->pix_fmt, ost->st->codec->width, ost->st->codec->height);
 +        opkt.data = (uint8_t *)&pict;
 +        opkt.size = sizeof(AVPicture);
 +        opkt.flags |= AV_PKT_FLAG_KEY;
 +    }
  
-     write_frame(of->ctx, &opkt, ost->st->codec, ost->bitstream_filters);
+     write_frame(of->ctx, &opkt, ost);
      ost->st->codec->frame_number++;
-     ost->frame_number++;
      av_free_packet(&opkt);
  }
  
diff --cc ffmpeg.c
index 1fe9fa67fee2e1bc775e3704c3137fa3a0e1d6d8,0ec3b241caffd2652b110992a3f834f3a47fed52..fe15eea3f7e0a461a407a309198f973ac6b33277
+++ b/ffmpeg.c
@@@ -810,17 -456,17 +810,26 @@@ void av_noreturn exit_program(int ret
          if (!(s->oformat->flags & AVFMT_NOFILE) && s->pb)
              avio_close(s->pb);
          avformat_free_context(s);
 -        av_free(output_streams_for_file[i]);
 -        av_dict_free(&output_opts[i]);
 +        av_dict_free(&output_files[i].opts);
 +    }
++    for (i = 0; i < nb_output_streams; i++) {
++        AVBitStreamFilterContext *bsfc = output_streams[i].bitstream_filters;
++        while (bsfc) {
++            AVBitStreamFilterContext *next = bsfc->next;
++            av_bitstream_filter_close(bsfc);
++            bsfc = next;
++        }
++        output_streams[i].bitstream_filters = NULL;
+     }
 -    for(i=0;i<nb_input_files;i++) {
 -        av_close_input_file(input_files[i].ctx);
 +    for (i = 0; i < nb_input_files; i++) {
 +        avformat_close_input(&input_files[i].ctx);
      }
 -    for (i = 0; i < nb_input_streams; i++)
 +    for (i = 0; i < nb_input_streams; i++) {
 +        av_freep(&input_streams[i].decoded_frame);
 +        av_freep(&input_streams[i].filtered_frame);
          av_dict_free(&input_streams[i].opts);
 -
 -    av_free(intra_matrix);
 -    av_free(inter_matrix);
 +        free_buffer_pool(&input_streams[i]);
 +    }
  
      if (vstats_file)
          fclose(vstats_file);
@@@ -922,59 -612,129 +931,61 @@@ static void choose_sample_rate(AVStrea
  
  static void choose_pixel_fmt(AVStream *st, AVCodec *codec)
  {
 -    if(codec && codec->pix_fmts){
 -        const enum PixelFormat *p= codec->pix_fmts;
 -        if(st->codec->strict_std_compliance <= FF_COMPLIANCE_UNOFFICIAL){
 -            if(st->codec->codec_id==CODEC_ID_MJPEG){
 -                p= (const enum PixelFormat[]){PIX_FMT_YUVJ420P, PIX_FMT_YUVJ422P, PIX_FMT_YUV420P, PIX_FMT_YUV422P, PIX_FMT_NONE};
 -            }else if(st->codec->codec_id==CODEC_ID_LJPEG){
 -                p= (const enum PixelFormat[]){PIX_FMT_YUVJ420P, PIX_FMT_YUVJ422P, PIX_FMT_YUVJ444P, PIX_FMT_YUV420P, PIX_FMT_YUV422P, PIX_FMT_YUV444P, PIX_FMT_BGRA, PIX_FMT_NONE};
 +    if (codec && codec->pix_fmts) {
 +        const enum PixelFormat *p = codec->pix_fmts;
 +        int has_alpha= av_pix_fmt_descriptors[st->codec->pix_fmt].nb_components % 2 == 0;
 +        enum PixelFormat best= PIX_FMT_NONE;
 +        if (st->codec->strict_std_compliance <= FF_COMPLIANCE_UNOFFICIAL) {
 +            if (st->codec->codec_id == CODEC_ID_MJPEG) {
 +                p = (const enum PixelFormat[]) { PIX_FMT_YUVJ420P, PIX_FMT_YUVJ422P, PIX_FMT_YUV420P, PIX_FMT_YUV422P, PIX_FMT_NONE };
 +            } else if (st->codec->codec_id == CODEC_ID_LJPEG) {
 +                p = (const enum PixelFormat[]) { PIX_FMT_YUVJ420P, PIX_FMT_YUVJ422P, PIX_FMT_YUVJ444P, PIX_FMT_YUV420P,
 +                                                 PIX_FMT_YUV422P, PIX_FMT_YUV444P, PIX_FMT_BGRA, PIX_FMT_NONE };
              }
          }
 -        for(; *p!=-1; p++){
 -            if(*p == st->codec->pix_fmt)
 +        for (; *p != PIX_FMT_NONE; p++) {
 +            best= avcodec_find_best_pix_fmt2(best, *p, st->codec->pix_fmt, has_alpha, NULL);
 +            if (*p == st->codec->pix_fmt)
                  break;
          }
 -        if (*p == -1) {
 -            if(st->codec->pix_fmt != PIX_FMT_NONE)
 +        if (*p == PIX_FMT_NONE) {
 +            if (st->codec->pix_fmt != PIX_FMT_NONE)
                  av_log(NULL, AV_LOG_WARNING,
 -                        "Incompatible pixel format '%s' for codec '%s', auto-selecting format '%s'\n",
 -                        av_pix_fmt_descriptors[st->codec->pix_fmt].name,
 -                        codec->name,
 -                        av_pix_fmt_descriptors[codec->pix_fmts[0]].name);
 -            st->codec->pix_fmt = codec->pix_fmts[0];
 -        }
 -    }
 -}
 -
 -static OutputStream *new_output_stream(AVFormatContext *oc, int file_idx, AVCodec *codec)
 -{
 -    OutputStream *ost;
 -    AVStream *st = av_new_stream(oc, oc->nb_streams < nb_streamid_map ? streamid_map[oc->nb_streams] : 0);
 -    int idx      = oc->nb_streams - 1;
 -
 -    if (!st) {
 -        av_log(NULL, AV_LOG_ERROR, "Could not alloc stream.\n");
 -        exit_program(1);
 -    }
 -
 -    output_streams_for_file[file_idx] =
 -        grow_array(output_streams_for_file[file_idx],
 -                   sizeof(*output_streams_for_file[file_idx]),
 -                   &nb_output_streams_for_file[file_idx],
 -                   oc->nb_streams);
 -    ost = output_streams_for_file[file_idx][idx] =
 -        av_mallocz(sizeof(OutputStream));
 -    if (!ost) {
 -        fprintf(stderr, "Could not alloc output stream\n");
 -        exit_program(1);
 -    }
 -    ost->file_index = file_idx;
 -    ost->index = idx;
 -    ost->st    = st;
 -    ost->enc   = codec;
 -    if (codec)
 -        ost->opts  = filter_codec_opts(codec_opts, codec->id, oc, st);
 -
 -    avcodec_get_context_defaults3(st->codec, codec);
 -
 -    ost->sws_flags = av_get_int(sws_opts, "sws_flags", NULL);
 -    return ost;
 -}
 -
 -static int read_avserver_streams(AVFormatContext *s, const char *filename)
 -{
 -    int i, err;
 -    AVFormatContext *ic = NULL;
 -
 -    err = avformat_open_input(&ic, filename, NULL, NULL);
 -    if (err < 0)
 -        return err;
 -    /* copy stream format */
 -    for(i=0;i<ic->nb_streams;i++) {
 -        AVStream *st;
 -        OutputStream *ost;
 -        AVCodec *codec;
 -
 -        codec = avcodec_find_encoder(ic->streams[i]->codec->codec_id);
 -        ost   = new_output_stream(s, nb_output_files, codec);
 -        st    = ost->st;
 -
 -        // FIXME: a more elegant solution is needed
 -        memcpy(st, ic->streams[i], sizeof(AVStream));
 -        st->info = NULL;
 -        avcodec_copy_context(st->codec, ic->streams[i]->codec);
 -
 -        if (st->codec->codec_type == AVMEDIA_TYPE_AUDIO) {
 -            if (audio_stream_copy) {
 -                st->stream_copy = 1;
 -            } else
 -                choose_sample_fmt(st, codec);
 -        } else if (st->codec->codec_type == AVMEDIA_TYPE_VIDEO) {
 -            if (video_stream_copy) {
 -                st->stream_copy = 1;
 -            } else
 -                choose_pixel_fmt(st, codec);
 +                       "Incompatible pixel format '%s' for codec '%s', auto-selecting format '%s'\n",
 +                       av_pix_fmt_descriptors[st->codec->pix_fmt].name,
 +                       codec->name,
 +                       av_pix_fmt_descriptors[best].name);
 +            st->codec->pix_fmt = best;
          }
      }
 -
 -    av_close_input_file(ic);
 -    return 0;
  }
  
 -static double
 -get_sync_ipts(const OutputStream *ost)
 +static double get_sync_ipts(const OutputStream *ost)
  {
      const InputStream *ist = ost->sync_ist;
 -    return (double)(ist->pts - start_time)/AV_TIME_BASE;
 +    OutputFile *of = &output_files[ost->file_index];
 +    return (double)(ist->pts - of->start_time) / AV_TIME_BASE;
  }
  
- static void write_frame(AVFormatContext *s, AVPacket *pkt, AVCodecContext *avctx, AVBitStreamFilterContext *bsfc)
 -static void write_frame(AVFormatContext *s, AVPacket *pkt, AVCodecContext *avctx, AVBitStreamFilterContext *bsfc){
++static void write_frame(AVFormatContext *s, AVPacket *pkt, OutputStream *ost)
 +{
++    AVBitStreamFilterContext *bsfc = ost->bitstream_filters;
++    AVCodecContext          *avctx = ost->st->codec;
      int ret;
  
 -    while(bsfc){
 -        AVPacket new_pkt= *pkt;
 -        int a= av_bitstream_filter_filter(bsfc, avctx, NULL,
 -                                          &new_pkt.data, &new_pkt.size,
 -                                          pkt->data, pkt->size,
 -                                          pkt->flags & AV_PKT_FLAG_KEY);
 -        if(a>0){
 +    while (bsfc) {
 +        AVPacket new_pkt = *pkt;
 +        int a = av_bitstream_filter_filter(bsfc, avctx, NULL,
 +                                           &new_pkt.data, &new_pkt.size,
 +                                           pkt->data, pkt->size,
 +                                           pkt->flags & AV_PKT_FLAG_KEY);
 +        if (a > 0) {
              av_free_packet(pkt);
 -            new_pkt.destruct= av_destruct_packet;
 -        } else if(a<0){
 -            fprintf(stderr, "%s failed for stream %d, codec %s",
 -                    bsfc->filter->name, pkt->stream_index,
 -                    avctx->codec ? avctx->codec->name : "copy");
 +            new_pkt.destruct = av_destruct_packet;
 +        } else if (a < 0) {
 +            av_log(NULL, AV_LOG_ERROR, "%s failed for stream %d, codec %s",
 +                   bsfc->filter->name, pkt->stream_index,
 +                   avctx->codec ? avctx->codec->name : "copy");
              print_error("", a);
              if (exit_on_error)
                  exit_program(1);
          print_error("av_interleaved_write_frame()", ret);
          exit_program(1);
      }
++    ost->frame_number++;
  }
  
 -#define MAX_AUDIO_PACKET_SIZE (128 * 1024)
 +static void generate_silence(uint8_t* buf, enum AVSampleFormat sample_fmt, size_t size)
 +{
 +    int fill_char = 0x00;
 +    if (sample_fmt == AV_SAMPLE_FMT_U8)
 +        fill_char = 0x80;
 +    memset(buf, fill_char, size);
 +}
  
 -static void do_audio_out(AVFormatContext *s,
 -                         OutputStream *ost,
 -                         InputStream *ist,
 -                         unsigned char *buf, int size)
 +static void do_audio_out(AVFormatContext *s, OutputStream *ost,
 +                         InputStream *ist, AVFrame *decoded_frame)
  {
      uint8_t *buftmp;
      int64_t audio_out_size, audio_buf_size;
@@@ -1182,13 -952,13 +1194,13 @@@ need_realloc
                  exit_program(1);
              }
              audio_size += ret;
 -            pkt.stream_index= ost->index;
 -            pkt.data= audio_out;
 -            pkt.size= ret;
 -            if(enc->coded_frame && enc->coded_frame->pts != AV_NOPTS_VALUE)
 -                pkt.pts= av_rescale_q(enc->coded_frame->pts, enc->time_base, ost->st->time_base);
 +            pkt.stream_index = ost->index;
 +            pkt.data = audio_out;
 +            pkt.size = ret;
 +            if (enc->coded_frame && enc->coded_frame->pts != AV_NOPTS_VALUE)
 +                pkt.pts = av_rescale_q(enc->coded_frame->pts, enc->time_base, ost->st->time_base);
              pkt.flags |= AV_PKT_FLAG_KEY;
--            write_frame(s, &pkt, enc, ost->bitstream_filters);
++            write_frame(s, &pkt, ost);
  
              ost->sync_opts += enc->frame_size;
          }
              exit_program(1);
          }
          audio_size += ret;
 -        pkt.stream_index= ost->index;
 -        pkt.data= audio_out;
 -        pkt.size= ret;
 -        if(enc->coded_frame && enc->coded_frame->pts != AV_NOPTS_VALUE)
 -            pkt.pts= av_rescale_q(enc->coded_frame->pts, enc->time_base, ost->st->time_base);
 +        pkt.stream_index = ost->index;
 +        pkt.data = audio_out;
 +        pkt.size = ret;
 +        if (enc->coded_frame && enc->coded_frame->pts != AV_NOPTS_VALUE)
 +            pkt.pts = av_rescale_q(enc->coded_frame->pts, enc->time_base, ost->st->time_base);
          pkt.flags |= AV_PKT_FLAG_KEY;
--        write_frame(s, &pkt, enc, ost->bitstream_filters);
++        write_frame(s, &pkt, ost);
      }
  }
  
@@@ -1325,7 -1098,7 +1337,7 @@@ static void do_subtitle_out(AVFormatCon
              else
                  pkt.pts += 90 * sub->end_display_time;
          }
--        write_frame(s, &pkt, ost->st->codec, ost->bitstream_filters);
++        write_frame(s, &pkt, ost);
      }
  }
  
@@@ -1384,94 -1191,30 +1396,94 @@@ static void do_video_resample(OutputStr
                  exit_program(1);
              }
          }
 -        sws_scale(ost->img_resample_ctx, formatted_picture->data, formatted_picture->linesize,
 -              0, ost->resample_height, final_picture->data, final_picture->linesize);
 +        sws_scale(ost->img_resample_ctx, in_picture->data, in_picture->linesize,
 +              0, ost->resample_height, (*out_picture)->data, (*out_picture)->linesize);
      }
  #endif
 +}
 +
 +
 +static void do_video_out(AVFormatContext *s,
 +                         OutputStream *ost,
 +                         InputStream *ist,
 +                         AVFrame *in_picture,
 +                         int *frame_size, float quality)
 +{
 +    int nb_frames, i, ret, format_video_sync;
 +    AVFrame *final_picture;
 +    AVCodecContext *enc;
 +    double sync_ipts;
 +    double duration = 0;
 +
 +    enc = ost->st->codec;
 +
 +    if (ist->st->start_time != AV_NOPTS_VALUE && ist->st->first_dts != AV_NOPTS_VALUE) {
 +        duration = FFMAX(av_q2d(ist->st->time_base), av_q2d(ist->st->codec->time_base));
 +        if(ist->st->avg_frame_rate.num)
 +            duration= FFMAX(duration, 1/av_q2d(ist->st->avg_frame_rate));
 +
 +        duration /= av_q2d(enc->time_base);
 +    }
 +
 +    sync_ipts = get_sync_ipts(ost) / av_q2d(enc->time_base);
 +
 +    /* by default, we output a single frame */
 +    nb_frames = 1;
 +
 +    *frame_size = 0;
 +
 +    format_video_sync = video_sync_method;
 +    if (format_video_sync < 0)
 +        format_video_sync = (s->oformat->flags & AVFMT_VARIABLE_FPS) ? ((s->oformat->flags & AVFMT_NOTIMESTAMPS) ? 0 : 2) : 1;
 +
 +    if (format_video_sync) {
 +        double vdelta = sync_ipts - ost->sync_opts + duration;
 +        // FIXME set to 0.5 after we fix some dts/pts bugs like in avidec.c
 +        if (vdelta < -1.1)
 +            nb_frames = 0;
 +        else if (format_video_sync == 2) {
 +            if (vdelta <= -0.6) {
 +                nb_frames = 0;
 +            } else if (vdelta > 0.6)
 +                ost->sync_opts = lrintf(sync_ipts);
 +        } else if (vdelta > 1.1)
 +            nb_frames = lrintf(vdelta);
 +//fprintf(stderr, "vdelta:%f, ost->sync_opts:%"PRId64", ost->sync_ipts:%f nb_frames:%d\n", vdelta, ost->sync_opts, get_sync_ipts(ost), nb_frames);
 +        if (nb_frames == 0) {
 +            ++nb_frames_drop;
 +            av_log(NULL, AV_LOG_VERBOSE, "*** drop!\n");
 +        } else if (nb_frames > 1) {
 +            nb_frames_dup += nb_frames - 1;
 +            av_log(NULL, AV_LOG_VERBOSE, "*** %d dup!\n", nb_frames - 1);
 +        }
 +    } else
 +        ost->sync_opts = lrintf(sync_ipts);
 +
 +    nb_frames = FFMIN(nb_frames, ost->max_frames - ost->frame_number);
 +    if (nb_frames <= 0)
 +        return;
 +
 +    do_video_resample(ost, ist, in_picture, &final_picture);
  
      /* duplicates frame if needed */
 -    for(i=0;i<nb_frames;i++) {
 +    for (i = 0; i < nb_frames; i++) {
          AVPacket pkt;
          av_init_packet(&pkt);
 -        pkt.stream_index= ost->index;
 +        pkt.stream_index = ost->index;
  
 -        if (s->oformat->flags & AVFMT_RAWPICTURE) {
 +        if (s->oformat->flags & AVFMT_RAWPICTURE &&
 +            enc->codec->id == CODEC_ID_RAWVIDEO) {
              /* raw pictures are written as AVPicture structure to
 -               avoid any copies. We support temorarily the older
 +               avoid any copies. We support temporarily the older
                 method. */
 -            AVFrame* old_frame = enc->coded_frame;
 -            enc->coded_frame = dec->coded_frame; //FIXME/XXX remove this hack
 -            pkt.data= (uint8_t *)final_picture;
 -            pkt.size=  sizeof(AVPicture);
 -            pkt.pts= av_rescale_q(ost->sync_opts, enc->time_base, ost->st->time_base);
 +            enc->coded_frame->interlaced_frame = in_picture->interlaced_frame;
 +            enc->coded_frame->top_field_first  = in_picture->top_field_first;
 +            pkt.data   = (uint8_t *)final_picture;
 +            pkt.size   =  sizeof(AVPicture);
 +            pkt.pts    = av_rescale_q(ost->sync_opts, enc->time_base, ost->st->time_base);
              pkt.flags |= AV_PKT_FLAG_KEY;
  
--            write_frame(s, &pkt, ost->st->codec, ost->bitstream_filters);
 -            enc->coded_frame = old_frame;
++            write_frame(s, &pkt, ost);
          } else {
              AVFrame big_picture;
  
     pkt.pts != AV_NOPTS_VALUE ? av_rescale(pkt.pts, enc->time_base.den, AV_TIME_BASE*(int64_t)enc->time_base.num) : -1,
     pkt.dts != AV_NOPTS_VALUE ? av_rescale(pkt.dts, enc->time_base.den, AV_TIME_BASE*(int64_t)enc->time_base.num) : -1);*/
  
 -                if(enc->coded_frame->key_frame)
 +                if (enc->coded_frame->key_frame)
                      pkt.flags |= AV_PKT_FLAG_KEY;
--                write_frame(s, &pkt, ost->st->codec, ost->bitstream_filters);
++                write_frame(s, &pkt, ost);
                  *frame_size = ret;
                  video_size += ret;
 -                //fprintf(stderr,"\nFrame: %3d size: %5d type: %d",
 -                //        enc->frame_number-1, ret, enc->pict_type);
 +                // fprintf(stderr,"\nFrame: %3d size: %5d type: %d",
 +                //         enc->frame_number-1, ret, enc->pict_type);
                  /* if two pass, output log */
                  if (ost->logfile && enc->stats_out) {
                      fprintf(ost->logfile, "%s", enc->stats_out);
              }
          }
          ost->sync_opts++;
--        ost->frame_number++;
      }
  }
  
@@@ -1712,645 -1441,629 +1723,644 @@@ static void print_report(OutputFile *ou
      }
  }
  
 -static void generate_silence(uint8_t* buf, enum AVSampleFormat sample_fmt, size_t size)
 -{
 -    int fill_char = 0x00;
 -    if (sample_fmt == AV_SAMPLE_FMT_U8)
 -        fill_char = 0x80;
 -    memset(buf, fill_char, size);
 -}
 -
 -/* pkt = NULL means EOF (needed to flush decoder buffers) */
 -static int output_packet(InputStream *ist, int ist_index,
 -                         OutputStream **ost_table, int nb_ostreams,
 -                         const AVPacket *pkt)
 +static void flush_encoders(OutputStream *ost_table, int nb_ostreams)
  {
 -    AVFormatContext *os;
 -    OutputStream *ost;
 -    int ret, i;
 -    int got_output;
 -    AVFrame picture;
 -    void *buffer_to_free = NULL;
 -    static unsigned int samples_size= 0;
 -    AVSubtitle subtitle, *subtitle_to_free;
 -    int64_t pkt_pts = AV_NOPTS_VALUE;
 -#if CONFIG_AVFILTER
 -    int frame_available;
 -#endif
 -    float quality;
 -
 -    AVPacket avpkt;
 -    int bps = av_get_bytes_per_sample(ist->st->codec->sample_fmt);
 +    int i, ret;
  
 -    if(ist->next_pts == AV_NOPTS_VALUE)
 -        ist->next_pts= ist->pts;
 +    for (i = 0; i < nb_ostreams; i++) {
 +        OutputStream   *ost = &ost_table[i];
 +        AVCodecContext *enc = ost->st->codec;
 +        AVFormatContext *os = output_files[ost->file_index].ctx;
  
 -    if (pkt == NULL) {
 -        /* EOF handling */
 -        av_init_packet(&avpkt);
 -        avpkt.data = NULL;
 -        avpkt.size = 0;
 -        goto handle_eof;
 -    } else {
 -        avpkt = *pkt;
 -    }
 +        if (!ost->encoding_needed)
 +            continue;
  
 -    if(pkt->dts != AV_NOPTS_VALUE)
 -        ist->next_pts = ist->pts = av_rescale_q(pkt->dts, ist->st->time_base, AV_TIME_BASE_Q);
 -    if(pkt->pts != AV_NOPTS_VALUE)
 -        pkt_pts = av_rescale_q(pkt->pts, ist->st->time_base, AV_TIME_BASE_Q);
 +        if (ost->st->codec->codec_type == AVMEDIA_TYPE_AUDIO && enc->frame_size <= 1)
 +            continue;
 +        if (ost->st->codec->codec_type == AVMEDIA_TYPE_VIDEO && (os->oformat->flags & AVFMT_RAWPICTURE) && enc->codec->id == CODEC_ID_RAWVIDEO)
 +            continue;
  
 -    //while we have more to decode or while the decoder did output something on EOF
 -    while (avpkt.size > 0 || (!pkt && got_output)) {
 -        uint8_t *data_buf, *decoded_data_buf;
 -        int data_size, decoded_data_size;
 -    handle_eof:
 -        ist->pts= ist->next_pts;
 +        for (;;) {
 +            AVPacket pkt;
 +            int fifo_bytes;
 +            av_init_packet(&pkt);
 +            pkt.stream_index = ost->index;
  
 -        if(avpkt.size && avpkt.size != pkt->size &&
 -           ((!ist->showed_multi_packet_warning && verbose>0) || verbose>1)){
 -            fprintf(stderr, "Multiple frames in a packet from stream %d\n", pkt->stream_index);
 -            ist->showed_multi_packet_warning=1;
 -        }
 +            switch (ost->st->codec->codec_type) {
 +            case AVMEDIA_TYPE_AUDIO:
 +                fifo_bytes = av_fifo_size(ost->fifo);
 +                ret = 0;
 +                /* encode any samples remaining in fifo */
 +                if (fifo_bytes > 0) {
 +                    int osize = av_get_bytes_per_sample(enc->sample_fmt);
 +                    int fs_tmp = enc->frame_size;
 +
 +                    av_fifo_generic_read(ost->fifo, audio_buf, fifo_bytes, NULL);
 +                    if (enc->codec->capabilities & CODEC_CAP_SMALL_LAST_FRAME) {
 +                        enc->frame_size = fifo_bytes / (osize * enc->channels);
 +                    } else { /* pad */
 +                        int frame_bytes = enc->frame_size*osize*enc->channels;
 +                        if (allocated_audio_buf_size < frame_bytes)
 +                            exit_program(1);
 +                        generate_silence(audio_buf+fifo_bytes, enc->sample_fmt, frame_bytes - fifo_bytes);
 +                    }
  
 -        /* decode the packet if needed */
 -        decoded_data_buf = NULL; /* fail safe */
 -        decoded_data_size= 0;
 -        data_buf  = avpkt.data;
 -        data_size = avpkt.size;
 -        subtitle_to_free = NULL;
 -        if (ist->decoding_needed) {
 -            switch(ist->st->codec->codec_type) {
 -            case AVMEDIA_TYPE_AUDIO:{
 -                if(pkt && samples_size < FFMAX(pkt->size*sizeof(*samples), AVCODEC_MAX_AUDIO_FRAME_SIZE)) {
 -                    samples_size = FFMAX(pkt->size*sizeof(*samples), AVCODEC_MAX_AUDIO_FRAME_SIZE);
 -                    av_free(samples);
 -                    samples= av_malloc(samples_size);
 +                    ret = avcodec_encode_audio(enc, bit_buffer, bit_buffer_size, (short *)audio_buf);
 +                    pkt.duration = av_rescale((int64_t)enc->frame_size*ost->st->time_base.den,
 +                                              ost->st->time_base.num, enc->sample_rate);
 +                    enc->frame_size = fs_tmp;
                  }
 -                decoded_data_size= samples_size;
 -                    /* XXX: could avoid copy if PCM 16 bits with same
 -                       endianness as CPU */
 -                ret = avcodec_decode_audio3(ist->st->codec, samples, &decoded_data_size,
 -                                            &avpkt);
 -                if (ret < 0)
 -                    return ret;
 -                avpkt.data += ret;
 -                avpkt.size -= ret;
 -                data_size   = ret;
 -                got_output  = decoded_data_size > 0;
 -                /* Some bug in mpeg audio decoder gives */
 -                /* decoded_data_size < 0, it seems they are overflows */
 -                if (!got_output) {
 -                    /* no audio frame */
 -                    continue;
 +                if (ret <= 0) {
 +                    ret = avcodec_encode_audio(enc, bit_buffer, bit_buffer_size, NULL);
                  }
 -                decoded_data_buf = (uint8_t *)samples;
 -                ist->next_pts += ((int64_t)AV_TIME_BASE/bps * decoded_data_size) /
 -                    (ist->st->codec->sample_rate * ist->st->codec->channels);
 -                break;}
 -            case AVMEDIA_TYPE_VIDEO:
 -                    decoded_data_size = (ist->st->codec->width * ist->st->codec->height * 3) / 2;
 -                    /* XXX: allocate picture correctly */
 -                    avcodec_get_frame_defaults(&picture);
 -                    avpkt.pts = pkt_pts;
 -                    avpkt.dts = ist->pts;
 -                    pkt_pts = AV_NOPTS_VALUE;
 -
 -                    ret = avcodec_decode_video2(ist->st->codec,
 -                                                &picture, &got_output, &avpkt);
 -                    quality = same_quality ? picture.quality : 0;
 -                    if (ret < 0)
 -                        return ret;
 -                    if (!got_output) {
 -                        /* no picture yet */
 -                        goto discard_packet;
 -                    }
 -                    ist->next_pts = ist->pts = guess_correct_pts(&ist->pts_ctx, picture.pkt_pts, picture.pkt_dts);
 -                    if (ist->st->codec->time_base.num != 0) {
 -                        int ticks= ist->st->parser ? ist->st->parser->repeat_pict+1 : ist->st->codec->ticks_per_frame;
 -                        ist->next_pts += ((int64_t)AV_TIME_BASE *
 -                                          ist->st->codec->time_base.num * ticks) /
 -                            ist->st->codec->time_base.den;
 -                    }
 -                    avpkt.size = 0;
 -                    buffer_to_free = NULL;
 -                    pre_process_video_frame(ist, (AVPicture *)&picture, &buffer_to_free);
 -                    break;
 -            case AVMEDIA_TYPE_SUBTITLE:
 -                ret = avcodec_decode_subtitle2(ist->st->codec,
 -                                               &subtitle, &got_output, &avpkt);
 -                if (ret < 0)
 -                    return ret;
 -                if (!got_output) {
 -                    goto discard_packet;
 +                if (ret < 0) {
 +                    av_log(NULL, AV_LOG_FATAL, "Audio encoding failed\n");
 +                    exit_program(1);
                  }
 -                subtitle_to_free = &subtitle;
 -                avpkt.size = 0;
 -                break;
 -            default:
 -                return -1;
 -            }
 -        } else {
 -            switch(ist->st->codec->codec_type) {
 -            case AVMEDIA_TYPE_AUDIO:
 -                ist->next_pts += ((int64_t)AV_TIME_BASE * ist->st->codec->frame_size) /
 -                    ist->st->codec->sample_rate;
 +                audio_size += ret;
 +                pkt.flags  |= AV_PKT_FLAG_KEY;
                  break;
              case AVMEDIA_TYPE_VIDEO:
 -                if (ist->st->codec->time_base.num != 0) {
 -                    int ticks= ist->st->parser ? ist->st->parser->repeat_pict+1 : ist->st->codec->ticks_per_frame;
 -                    ist->next_pts += ((int64_t)AV_TIME_BASE *
 -                                      ist->st->codec->time_base.num * ticks) /
 -                        ist->st->codec->time_base.den;
 +                ret = avcodec_encode_video(enc, bit_buffer, bit_buffer_size, NULL);
 +                if (ret < 0) {
 +                    av_log(NULL, AV_LOG_FATAL, "Video encoding failed\n");
 +                    exit_program(1);
                  }
 -                break;
 -            }
 -            ret = avpkt.size;
 -            avpkt.size = 0;
 -        }
 -
 -#if CONFIG_AVFILTER
 -        if (ist->st->codec->codec_type == AVMEDIA_TYPE_VIDEO) {
 -            for (i = 0; i < nb_ostreams; i++) {
 -                ost = ost_table[i];
 -                if (ost->input_video_filter && ost->source_index == ist_index) {
 -                    AVRational sar;
 -                    if (ist->st->sample_aspect_ratio.num)
 -                        sar = ist->st->sample_aspect_ratio;
 -                    else
 -                        sar = ist->st->codec->sample_aspect_ratio;
 -                    // add it to be filtered
 -                    av_vsrc_buffer_add_frame(ost->input_video_filter, &picture,
 -                                             ist->pts,
 -                                             sar);
 +                video_size += ret;
 +                if (enc->coded_frame && enc->coded_frame->key_frame)
 +                    pkt.flags |= AV_PKT_FLAG_KEY;
 +                if (ost->logfile && enc->stats_out) {
 +                    fprintf(ost->logfile, "%s", enc->stats_out);
                  }
 +                break;
 +            default:
 +                ret = -1;
              }
 -        }
 -#endif
  
 -        // preprocess audio (volume)
 -        if (ist->st->codec->codec_type == AVMEDIA_TYPE_AUDIO) {
 -            if (audio_volume != 256) {
 -                short *volp;
 -                volp = samples;
 -                for(i=0;i<(decoded_data_size / sizeof(short));i++) {
 -                    int v = ((*volp) * audio_volume + 128) >> 8;
 -                    if (v < -32768) v = -32768;
 -                    if (v >  32767) v = 32767;
 -                    *volp++ = v;
 -                }
 -            }
 +            if (ret <= 0)
 +                break;
 +            pkt.data = bit_buffer;
 +            pkt.size = ret;
 +            if (enc->coded_frame && enc->coded_frame->pts != AV_NOPTS_VALUE)
 +                pkt.pts = av_rescale_q(enc->coded_frame->pts, enc->time_base, ost->st->time_base);
-             write_frame(os, &pkt, ost->st->codec, ost->bitstream_filters);
++            write_frame(os, &pkt, ost);
          }
 +    }
 +}
  
 -        /* frame rate emulation */
 -        if (rate_emu) {
 -            int64_t pts = av_rescale(ist->pts, 1000000, AV_TIME_BASE);
 -            int64_t now = av_gettime() - ist->start;
 -            if (pts > now)
 -                usleep(pts - now);
 -        }
 -        /* if output time reached then transcode raw format,
 -           encode packets and output them */
 -        if (start_time == 0 || ist->pts >= start_time)
 -            for(i=0;i<nb_ostreams;i++) {
 -                int frame_size;
 -
 -                ost = ost_table[i];
 -                if (ost->source_index == ist_index) {
 -#if CONFIG_AVFILTER
 -                frame_available = ist->st->codec->codec_type != AVMEDIA_TYPE_VIDEO ||
 -                    !ost->output_video_filter || avfilter_poll_frame(ost->output_video_filter->inputs[0]);
 -                while (frame_available) {
 -                    AVRational ist_pts_tb;
 -                    if (ist->st->codec->codec_type == AVMEDIA_TYPE_VIDEO && ost->output_video_filter)
 -                        get_filtered_video_frame(ost->output_video_filter, &picture, &ost->picref, &ist_pts_tb);
 -                    if (ost->picref)
 -                        ist->pts = av_rescale_q(ost->picref->pts, ist_pts_tb, AV_TIME_BASE_Q);
 -#endif
 -                    os = output_files[ost->file_index];
 -
 -                    /* set the input output pts pairs */
 -                    //ost->sync_ipts = (double)(ist->pts + input_files[ist->file_index].ts_offset - start_time)/ AV_TIME_BASE;
 -
 -                    if (ost->encoding_needed) {
 -                        av_assert0(ist->decoding_needed);
 -                        switch(ost->st->codec->codec_type) {
 -                        case AVMEDIA_TYPE_AUDIO:
 -                            do_audio_out(os, ost, ist, decoded_data_buf, decoded_data_size);
 -                            break;
 -                        case AVMEDIA_TYPE_VIDEO:
 -#if CONFIG_AVFILTER
 -                            if (ost->picref->video && !ost->frame_aspect_ratio)
 -                                ost->st->codec->sample_aspect_ratio = ost->picref->video->pixel_aspect;
 -#endif
 -                            do_video_out(os, ost, ist, &picture, &frame_size,
 -                                         same_quality ? quality : ost->st->codec->global_quality);
 -                            if (vstats_filename && frame_size)
 -                                do_video_stats(os, ost, frame_size);
 -                            break;
 -                        case AVMEDIA_TYPE_SUBTITLE:
 -                            do_subtitle_out(os, ost, ist, &subtitle,
 -                                            pkt->pts);
 -                            break;
 -                        default:
 -                            abort();
 -                        }
 -                    } else {
 -                        AVFrame avframe; //FIXME/XXX remove this
 -                        AVPacket opkt;
 -                        int64_t ost_tb_start_time= av_rescale_q(start_time, AV_TIME_BASE_Q, ost->st->time_base);
 +/*
 + * Check whether a packet from ist should be written into ost at this time
 + */
 +static int check_output_constraints(InputStream *ist, OutputStream *ost)
 +{
 +    OutputFile *of = &output_files[ost->file_index];
 +    int ist_index  = ist - input_streams;
  
 -                        av_init_packet(&opkt);
 +    if (ost->source_index != ist_index)
 +        return 0;
  
 -                        if ((!ost->frame_number && !(pkt->flags & AV_PKT_FLAG_KEY)) && !copy_initial_nonkeyframes)
 -#if !CONFIG_AVFILTER
 -                            continue;
 -#else
 -                            goto cont;
 -#endif
 +    if (of->start_time && ist->pts < of->start_time)
 +        return 0;
  
 -                        /* no reencoding needed : output the packet directly */
 -                        /* force the input stream PTS */
 +    if (of->recording_time != INT64_MAX &&
 +        av_compare_ts(ist->pts, AV_TIME_BASE_Q, of->recording_time + of->start_time,
 +                      (AVRational){ 1, 1000000 }) >= 0) {
 +        ost->is_past_recording_time = 1;
 +        return 0;
 +    }
  
 -                        avcodec_get_frame_defaults(&avframe);
 -                        ost->st->codec->coded_frame= &avframe;
 -                        avframe.key_frame = pkt->flags & AV_PKT_FLAG_KEY;
 +    return 1;
 +}
  
 -                        if(ost->st->codec->codec_type == AVMEDIA_TYPE_AUDIO)
 -                            audio_size += data_size;
 -                        else if (ost->st->codec->codec_type == AVMEDIA_TYPE_VIDEO) {
 -                            video_size += data_size;
 -                            ost->sync_opts++;
 -                        }
 +static void do_streamcopy(InputStream *ist, OutputStream *ost, const AVPacket *pkt)
 +{
 +    OutputFile *of = &output_files[ost->file_index];
 +    int64_t ost_tb_start_time = av_rescale_q(of->start_time, AV_TIME_BASE_Q, ost->st->time_base);
 +    AVPicture pict;
 +    AVPacket opkt;
  
 -                        opkt.stream_index= ost->index;
 -                        if(pkt->pts != AV_NOPTS_VALUE)
 -                            opkt.pts= av_rescale_q(pkt->pts, ist->st->time_base, ost->st->time_base) - ost_tb_start_time;
 -                        else
 -                            opkt.pts= AV_NOPTS_VALUE;
 -
 -                        if (pkt->dts == AV_NOPTS_VALUE)
 -                            opkt.dts = av_rescale_q(ist->pts, AV_TIME_BASE_Q, ost->st->time_base);
 -                        else
 -                            opkt.dts = av_rescale_q(pkt->dts, ist->st->time_base, ost->st->time_base);
 -                        opkt.dts -= ost_tb_start_time;
 -
 -                        opkt.duration = av_rescale_q(pkt->duration, ist->st->time_base, ost->st->time_base);
 -                        opkt.flags= pkt->flags;
 -
 -                        //FIXME remove the following 2 lines they shall be replaced by the bitstream filters
 -                        if(   ost->st->codec->codec_id != CODEC_ID_H264
 -                           && ost->st->codec->codec_id != CODEC_ID_MPEG1VIDEO
 -                           && ost->st->codec->codec_id != CODEC_ID_MPEG2VIDEO
 -                           ) {
 -                            if(av_parser_change(ist->st->parser, ost->st->codec, &opkt.data, &opkt.size, data_buf, data_size, pkt->flags & AV_PKT_FLAG_KEY))
 -                                opkt.destruct= av_destruct_packet;
 -                        } else {
 -                            opkt.data = data_buf;
 -                            opkt.size = data_size;
 -                        }
 +    av_init_packet(&opkt);
  
 -                        write_frame(os, &opkt, ost->st->codec, ost->bitstream_filters);
 -                        ost->st->codec->frame_number++;
 -                        ost->frame_number++;
 -                        av_free_packet(&opkt);
 -                    }
 -#if CONFIG_AVFILTER
 -                    cont:
 -                    frame_available = (ist->st->codec->codec_type == AVMEDIA_TYPE_VIDEO) &&
 -                                       ost->output_video_filter && avfilter_poll_frame(ost->output_video_filter->inputs[0]);
 -                    if (ost->picref)
 -                        avfilter_unref_buffer(ost->picref);
 -                }
 -#endif
 -                }
 -            }
 +    if ((!ost->frame_number && !(pkt->flags & AV_PKT_FLAG_KEY)) &&
 +        !ost->copy_initial_nonkeyframes)
 +        return;
  
 -        av_free(buffer_to_free);
 -        /* XXX: allocate the subtitles in the codec ? */
 -        if (subtitle_to_free) {
 -            avsubtitle_free(subtitle_to_free);
 -            subtitle_to_free = NULL;
 -        }
 +    /* force the input stream PTS */
 +    if (ost->st->codec->codec_type == AVMEDIA_TYPE_AUDIO)
 +        audio_size += pkt->size;
 +    else if (ost->st->codec->codec_type == AVMEDIA_TYPE_VIDEO) {
 +        video_size += pkt->size;
 +        ost->sync_opts++;
      }
 - discard_packet:
 -    if (pkt == NULL) {
 -        /* EOF handling */
  
 -        for(i=0;i<nb_ostreams;i++) {
 -            ost = ost_table[i];
 -            if (ost->source_index == ist_index) {
 -                AVCodecContext *enc= ost->st->codec;
 -                os = output_files[ost->file_index];
 -
 -                if(ost->st->codec->codec_type == AVMEDIA_TYPE_AUDIO && enc->frame_size <=1)
 -                    continue;
 -                if(ost->st->codec->codec_type == AVMEDIA_TYPE_VIDEO && (os->oformat->flags & AVFMT_RAWPICTURE))
 -                    continue;
 -
 -                if (ost->encoding_needed) {
 -                    for(;;) {
 -                        AVPacket pkt;
 -                        int fifo_bytes;
 -                        av_init_packet(&pkt);
 -                        pkt.stream_index= ost->index;
 -
 -                        switch(ost->st->codec->codec_type) {
 -                        case AVMEDIA_TYPE_AUDIO:
 -                            fifo_bytes = av_fifo_size(ost->fifo);
 -                            ret = 0;
 -                            /* encode any samples remaining in fifo */
 -                            if (fifo_bytes > 0) {
 -                                int osize = av_get_bytes_per_sample(enc->sample_fmt);
 -                                int fs_tmp = enc->frame_size;
 -
 -                                av_fifo_generic_read(ost->fifo, audio_buf, fifo_bytes, NULL);
 -                                if (enc->codec->capabilities & CODEC_CAP_SMALL_LAST_FRAME) {
 -                                    enc->frame_size = fifo_bytes / (osize * enc->channels);
 -                                } else { /* pad */
 -                                    int frame_bytes = enc->frame_size*osize*enc->channels;
 -                                    if (allocated_audio_buf_size < frame_bytes)
 -                                        exit_program(1);
 -                                    generate_silence(audio_buf+fifo_bytes, enc->sample_fmt, frame_bytes - fifo_bytes);
 -                                }
 -
 -                                ret = avcodec_encode_audio(enc, bit_buffer, bit_buffer_size, (short *)audio_buf);
 -                                pkt.duration = av_rescale((int64_t)enc->frame_size*ost->st->time_base.den,
 -                                                          ost->st->time_base.num, enc->sample_rate);
 -                                enc->frame_size = fs_tmp;
 -                            }
 -                            if(ret <= 0) {
 -                                ret = avcodec_encode_audio(enc, bit_buffer, bit_buffer_size, NULL);
 -                            }
 -                            if (ret < 0) {
 -                                fprintf(stderr, "Audio encoding failed\n");
 -                                exit_program(1);
 -                            }
 -                            audio_size += ret;
 -                            pkt.flags |= AV_PKT_FLAG_KEY;
 -                            break;
 -                        case AVMEDIA_TYPE_VIDEO:
 -                            ret = avcodec_encode_video(enc, bit_buffer, bit_buffer_size, NULL);
 -                            if (ret < 0) {
 -                                fprintf(stderr, "Video encoding failed\n");
 -                                exit_program(1);
 -                            }
 -                            video_size += ret;
 -                            if(enc->coded_frame && enc->coded_frame->key_frame)
 -                                pkt.flags |= AV_PKT_FLAG_KEY;
 -                            if (ost->logfile && enc->stats_out) {
 -                                fprintf(ost->logfile, "%s", enc->stats_out);
 -                            }
 -                            break;
 -                        default:
 -                            ret=-1;
 -                        }
 +    opkt.stream_index = ost->index;
 +    if (pkt->pts != AV_NOPTS_VALUE)
 +        opkt.pts = av_rescale_q(pkt->pts, ist->st->time_base, ost->st->time_base) - ost_tb_start_time;
 +    else
 +        opkt.pts = AV_NOPTS_VALUE;
  
 -                        if(ret<=0)
 -                            break;
 -                        pkt.data= bit_buffer;
 -                        pkt.size= ret;
 -                        if(enc->coded_frame && enc->coded_frame->pts != AV_NOPTS_VALUE)
 -                            pkt.pts= av_rescale_q(enc->coded_frame->pts, enc->time_base, ost->st->time_base);
 -                        write_frame(os, &pkt, ost->st->codec, ost->bitstream_filters);
 -                    }
 -                }
 -            }
 -        }
 +    if (pkt->dts == AV_NOPTS_VALUE)
 +        opkt.dts = av_rescale_q(ist->pts, AV_TIME_BASE_Q, ost->st->time_base);
 +    else
 +        opkt.dts = av_rescale_q(pkt->dts, ist->st->time_base, ost->st->time_base);
 +    opkt.dts -= ost_tb_start_time;
 +
 +    opkt.duration = av_rescale_q(pkt->duration, ist->st->time_base, ost->st->time_base);
 +    opkt.flags    = pkt->flags;
 +
 +    // FIXME remove the following 2 lines they shall be replaced by the bitstream filters
 +    if (  ost->st->codec->codec_id != CODEC_ID_H264
 +       && ost->st->codec->codec_id != CODEC_ID_MPEG1VIDEO
 +       && ost->st->codec->codec_id != CODEC_ID_MPEG2VIDEO
 +       ) {
 +        if (av_parser_change(ist->st->parser, ost->st->codec, &opkt.data, &opkt.size, pkt->data, pkt->size, pkt->flags & AV_PKT_FLAG_KEY))
 +            opkt.destruct = av_destruct_packet;
 +    } else {
 +        opkt.data = pkt->data;
 +        opkt.size = pkt->size;
 +    }
 +    if (of->ctx->oformat->flags & AVFMT_RAWPICTURE) {
 +        /* store AVPicture in AVPacket, as expected by the output format */
 +        avpicture_fill(&pict, opkt.data, ost->st->codec->pix_fmt, ost->st->codec->width, ost->st->codec->height);
 +        opkt.data = (uint8_t *)&pict;
 +        opkt.size = sizeof(AVPicture);
 +        opkt.flags |= AV_PKT_FLAG_KEY;
      }
  
-     write_frame(of->ctx, &opkt, ost->st->codec, ost->bitstream_filters);
 -    return 0;
++    write_frame(of->ctx, &opkt, ost);
 +    ost->st->codec->frame_number++;
-     ost->frame_number++;
 +    av_free_packet(&opkt);
  }
  
 -static void print_sdp(AVFormatContext **avc, int n)
 +static void rate_emu_sleep(InputStream *ist)
  {
 -    char sdp[2048];
 -
 -    av_sdp_create(avc, n, sdp, sizeof(sdp));
 -    printf("SDP:\n%s\n", sdp);
 -    fflush(stdout);
 +    if (input_files[ist->file_index].rate_emu) {
 +        int64_t pts = av_rescale(ist->pts, 1000000, AV_TIME_BASE);
 +        int64_t now = av_gettime() - ist->start;
 +        if (pts > now)
 +            usleep(pts - now);
 +    }
  }
  
 -static int copy_chapters(int infile, int outfile)
 +static int transcode_audio(InputStream *ist, AVPacket *pkt, int *got_output)
  {
 -    AVFormatContext *is = input_files[infile].ctx;
 -    AVFormatContext *os = output_files[outfile];
 -    int i;
 +    AVFrame *decoded_frame;
 +    AVCodecContext *avctx = ist->st->codec;
 +    int bps = av_get_bytes_per_sample(ist->st->codec->sample_fmt);
 +    int i, ret;
  
 -    for (i = 0; i < is->nb_chapters; i++) {
 -        AVChapter *in_ch = is->chapters[i], *out_ch;
 -        int64_t ts_off   = av_rescale_q(start_time - input_files[infile].ts_offset,
 -                                      AV_TIME_BASE_Q, in_ch->time_base);
 -        int64_t rt       = (recording_time == INT64_MAX) ? INT64_MAX :
 -                           av_rescale_q(recording_time, AV_TIME_BASE_Q, in_ch->time_base);
 +    if (!ist->decoded_frame && !(ist->decoded_frame = avcodec_alloc_frame()))
 +        return AVERROR(ENOMEM);
 +    else
 +        avcodec_get_frame_defaults(ist->decoded_frame);
 +    decoded_frame = ist->decoded_frame;
  
 +    ret = avcodec_decode_audio4(avctx, decoded_frame, got_output, pkt);
 +    if (ret < 0) {
 +        return ret;
 +    }
  
 -        if (in_ch->end < ts_off)
 -            continue;
 -        if (rt != INT64_MAX && in_ch->start > rt + ts_off)
 -            break;
 +    if (!*got_output) {
 +        /* no audio frame */
 +        return ret;
 +    }
  
 -        out_ch = av_mallocz(sizeof(AVChapter));
 -        if (!out_ch)
 -            return AVERROR(ENOMEM);
 +    /* if the decoder provides a pts, use it instead of the last packet pts.
 +       the decoder could be delaying output by a packet or more. */
 +    if (decoded_frame->pts != AV_NOPTS_VALUE)
 +        ist->next_pts = decoded_frame->pts;
 +
 +    /* increment next_pts to use for the case where the input stream does not
 +       have timestamps or there are multiple frames in the packet */
 +    ist->next_pts += ((int64_t)AV_TIME_BASE * decoded_frame->nb_samples) /
 +                     avctx->sample_rate;
 +
 +    // preprocess audio (volume)
 +    if (audio_volume != 256) {
 +        int decoded_data_size = decoded_frame->nb_samples * avctx->channels * bps;
 +        void *samples = decoded_frame->data[0];
 +        switch (avctx->sample_fmt) {
 +        case AV_SAMPLE_FMT_U8:
 +        {
 +            uint8_t *volp = samples;
 +            for (i = 0; i < (decoded_data_size / sizeof(*volp)); i++) {
 +                int v = (((*volp - 128) * audio_volume + 128) >> 8) + 128;
 +                *volp++ = av_clip_uint8(v);
 +            }
 +            break;
 +        }
 +        case AV_SAMPLE_FMT_S16:
 +        {
 +            int16_t *volp = samples;
 +            for (i = 0; i < (decoded_data_size / sizeof(*volp)); i++) {
 +                int v = ((*volp) * audio_volume + 128) >> 8;
 +                *volp++ = av_clip_int16(v);
 +            }
 +            break;
 +        }
 +        case AV_SAMPLE_FMT_S32:
 +        {
 +            int32_t *volp = samples;
 +            for (i = 0; i < (decoded_data_size / sizeof(*volp)); i++) {
 +                int64_t v = (((int64_t)*volp * audio_volume + 128) >> 8);
 +                *volp++ = av_clipl_int32(v);
 +            }
 +            break;
 +        }
 +        case AV_SAMPLE_FMT_FLT:
 +        {
 +            float *volp = samples;
 +            float scale = audio_volume / 256.f;
 +            for (i = 0; i < (decoded_data_size / sizeof(*volp)); i++) {
 +                *volp++ *= scale;
 +            }
 +            break;
 +        }
 +        case AV_SAMPLE_FMT_DBL:
 +        {
 +            double *volp = samples;
 +            double scale = audio_volume / 256.;
 +            for (i = 0; i < (decoded_data_size / sizeof(*volp)); i++) {
 +                *volp++ *= scale;
 +            }
 +            break;
 +        }
 +        default:
 +            av_log(NULL, AV_LOG_FATAL,
 +                   "Audio volume adjustment on sample format %s is not supported.\n",
 +                   av_get_sample_fmt_name(ist->st->codec->sample_fmt));
 +            exit_program(1);
 +        }
 +    }
  
 -        out_ch->id        = in_ch->id;
 -        out_ch->time_base = in_ch->time_base;
 -        out_ch->start     = FFMAX(0,  in_ch->start - ts_off);
 -        out_ch->end       = FFMIN(rt, in_ch->end   - ts_off);
 +    rate_emu_sleep(ist);
  
 -        if (metadata_chapters_autocopy)
 -            av_dict_copy(&out_ch->metadata, in_ch->metadata, 0);
 +    for (i = 0; i < nb_output_streams; i++) {
 +        OutputStream *ost = &output_streams[i];
  
 -        os->nb_chapters++;
 -        os->chapters = av_realloc(os->chapters, sizeof(AVChapter)*os->nb_chapters);
 -        if (!os->chapters)
 -            return AVERROR(ENOMEM);
 -        os->chapters[os->nb_chapters - 1] = out_ch;
 +        if (!check_output_constraints(ist, ost) || !ost->encoding_needed)
 +            continue;
 +        do_audio_out(output_files[ost->file_index].ctx, ost, ist, decoded_frame);
      }
 -    return 0;
 +
 +    return ret;
  }
  
 -static void parse_forced_key_frames(char *kf, OutputStream *ost,
 -                                    AVCodecContext *avctx)
 +static int transcode_video(InputStream *ist, AVPacket *pkt, int *got_output, int64_t *pkt_pts, int64_t *pkt_dts)
  {
 -    char *p;
 -    int n = 1, i;
 -    int64_t t;
 +    AVFrame *decoded_frame, *filtered_frame = NULL;
 +    void *buffer_to_free = NULL;
 +    int i, ret = 0;
 +    float quality = 0;
 +#if CONFIG_AVFILTER
 +    int frame_available = 1;
 +#endif
 +    int duration=0;
 +    int64_t *best_effort_timestamp;
 +    AVRational *frame_sample_aspect;
  
 -    for (p = kf; *p; p++)
 -        if (*p == ',')
 -            n++;
 -    ost->forced_kf_count = n;
 -    ost->forced_kf_pts = av_malloc(sizeof(*ost->forced_kf_pts) * n);
 -    if (!ost->forced_kf_pts) {
 -        av_log(NULL, AV_LOG_FATAL, "Could not allocate forced key frames array.\n");
 -        exit_program(1);
 -    }
 -    for (i = 0; i < n; i++) {
 -        p = i ? strchr(p, ',') + 1 : kf;
 -        t = parse_time_or_die("force_key_frames", p, 1);
 -        ost->forced_kf_pts[i] = av_rescale_q(t, AV_TIME_BASE_Q, avctx->time_base);
 +    if (!ist->decoded_frame && !(ist->decoded_frame = avcodec_alloc_frame()))
 +        return AVERROR(ENOMEM);
 +    else
 +        avcodec_get_frame_defaults(ist->decoded_frame);
 +    decoded_frame = ist->decoded_frame;
 +    pkt->pts  = *pkt_pts;
 +    pkt->dts  = *pkt_dts;
 +    *pkt_pts  = AV_NOPTS_VALUE;
 +
 +    if (pkt->duration) {
 +        duration = av_rescale_q(pkt->duration, ist->st->time_base, AV_TIME_BASE_Q);
 +    } else if(ist->st->codec->time_base.num != 0) {
 +        int ticks= ist->st->parser ? ist->st->parser->repeat_pict+1 : ist->st->codec->ticks_per_frame;
 +        duration = ((int64_t)AV_TIME_BASE *
 +                          ist->st->codec->time_base.num * ticks) /
 +                          ist->st->codec->time_base.den;
      }
 -}
  
 -/*
 - * The following code is the main loop of the file converter
 - */
 -static int transcode(AVFormatContext **output_files,
 -                     int nb_output_files,
 -                     InputFile *input_files,
 -                     int nb_input_files,
 -                     StreamMap *stream_maps, int nb_stream_maps)
 +    if(*pkt_dts != AV_NOPTS_VALUE && duration) {
 +        *pkt_dts += duration;
 +    }else
 +        *pkt_dts = AV_NOPTS_VALUE;
 +
 +    ret = avcodec_decode_video2(ist->st->codec,
 +                                decoded_frame, got_output, pkt);
 +    if (ret < 0)
 +        return ret;
 +
 +    quality = same_quant ? decoded_frame->quality : 0;
 +    if (!*got_output) {
 +        /* no picture yet */
 +        return ret;
 +    }
 +
 +    best_effort_timestamp= av_opt_ptr(avcodec_get_frame_class(), decoded_frame, "best_effort_timestamp");
 +    if(*best_effort_timestamp != AV_NOPTS_VALUE)
 +        ist->next_pts = ist->pts = *best_effort_timestamp;
 +
 +    ist->next_pts += duration;
 +    pkt->size = 0;
 +
 +    pre_process_video_frame(ist, (AVPicture *)decoded_frame, &buffer_to_free);
 +
 +#if CONFIG_AVFILTER
 +    frame_sample_aspect= av_opt_ptr(avcodec_get_frame_class(), decoded_frame, "sample_aspect_ratio");
 +    for(i=0;i<nb_output_streams;i++) {
 +        OutputStream *ost = ost = &output_streams[i];
 +        if(check_output_constraints(ist, ost)){
 +            if (!frame_sample_aspect->num)
 +                *frame_sample_aspect = ist->st->sample_aspect_ratio;
 +            decoded_frame->pts = ist->pts;
 +            if (ist->dr1 && decoded_frame->type==FF_BUFFER_TYPE_USER) {
 +                FrameBuffer      *buf = decoded_frame->opaque;
 +                AVFilterBufferRef *fb = avfilter_get_video_buffer_ref_from_arrays(
 +                                            decoded_frame->data, decoded_frame->linesize,
 +                                            AV_PERM_READ | AV_PERM_PRESERVE,
 +                                            ist->st->codec->width, ist->st->codec->height,
 +                                            ist->st->codec->pix_fmt);
 +
 +                avfilter_copy_frame_props(fb, decoded_frame);
 +                fb->pts                 = ist->pts;
 +                fb->buf->priv           = buf;
 +                fb->buf->free           = filter_release_buffer;
 +
 +                buf->refcount++;
 +                av_buffersrc_buffer(ost->input_video_filter, fb);
 +            } else
 +            if((av_vsrc_buffer_add_frame(ost->input_video_filter, decoded_frame, AV_VSRC_BUF_FLAG_OVERWRITE)) < 0){
 +                av_log(0, AV_LOG_FATAL, "Failed to inject frame into filter network\n");
 +                exit_program(1);
 +            }
 +        }
 +    }
 +#endif
 +
 +    rate_emu_sleep(ist);
 +
 +    for (i = 0; i < nb_output_streams; i++) {
 +        OutputStream *ost = &output_streams[i];
 +        int frame_size;
 +
 +        if (!check_output_constraints(ist, ost) || !ost->encoding_needed)
 +            continue;
 +
 +#if CONFIG_AVFILTER
 +        if (ost->input_video_filter) {
 +            frame_available = av_buffersink_poll_frame(ost->output_video_filter);
 +        }
 +        while (frame_available) {
 +            if (ost->output_video_filter) {
 +                AVRational ist_pts_tb = ost->output_video_filter->inputs[0]->time_base;
 +                if (av_buffersink_get_buffer_ref(ost->output_video_filter, &ost->picref, 0) < 0){
 +                    av_log(0, AV_LOG_WARNING, "AV Filter told us it has a frame available but failed to output one\n");
 +                    goto cont;
 +                }
 +                if (!ist->filtered_frame && !(ist->filtered_frame = avcodec_alloc_frame())) {
 +                    av_free(buffer_to_free);
 +                    return AVERROR(ENOMEM);
 +                } else
 +                    avcodec_get_frame_defaults(ist->filtered_frame);
 +                filtered_frame = ist->filtered_frame;
 +                *filtered_frame= *decoded_frame; //for me_threshold
 +                if (ost->picref) {
 +                    avfilter_fill_frame_from_video_buffer_ref(filtered_frame, ost->picref);
 +                    ist->pts = av_rescale_q(ost->picref->pts, ist_pts_tb, AV_TIME_BASE_Q);
 +                }
 +            }
 +            if (ost->picref->video && !ost->frame_aspect_ratio)
 +                ost->st->codec->sample_aspect_ratio = ost->picref->video->sample_aspect_ratio;
 +#else
 +            filtered_frame = decoded_frame;
 +#endif
 +
 +            do_video_out(output_files[ost->file_index].ctx, ost, ist, filtered_frame, &frame_size,
 +                         same_quant ? quality : ost->st->codec->global_quality);
 +            if (vstats_filename && frame_size)
 +                do_video_stats(output_files[ost->file_index].ctx, ost, frame_size);
 +#if CONFIG_AVFILTER
 +            cont:
 +            frame_available = ost->output_video_filter && av_buffersink_poll_frame(ost->output_video_filter);
 +            avfilter_unref_buffer(ost->picref);
 +        }
 +#endif
 +    }
 +
 +    av_free(buffer_to_free);
 +    return ret;
 +}
 +
 +static int transcode_subtitles(InputStream *ist, AVPacket *pkt, int *got_output)
  {
 -    int ret = 0, i, j, k, n, nb_ostreams = 0;
 -    AVFormatContext *is, *os;
 -    AVCodecContext *codec, *icodec;
 -    OutputStream *ost, **ost_table = NULL;
 -    InputStream *ist;
 -    char error[1024];
 -    int want_sdp = 1;
 -    uint8_t no_packet[MAX_FILES]={0};
 -    int no_packet_count=0;
 +    AVSubtitle subtitle;
 +    int i, ret = avcodec_decode_subtitle2(ist->st->codec,
 +                                          &subtitle, got_output, pkt);
 +    if (ret < 0)
 +        return ret;
 +    if (!*got_output)
 +        return ret;
  
 -    if (rate_emu)
 -        for (i = 0; i < nb_input_streams; i++)
 -            input_streams[i].start = av_gettime();
 +    rate_emu_sleep(ist);
  
 -    /* output stream init */
 -    nb_ostreams = 0;
 -    for(i=0;i<nb_output_files;i++) {
 -        os = output_files[i];
 -        if (!os->nb_streams && !(os->oformat->flags & AVFMT_NOSTREAMS)) {
 -            av_dump_format(output_files[i], i, output_files[i]->filename, 1);
 -            fprintf(stderr, "Output file #%d does not contain any stream\n", i);
 -            ret = AVERROR(EINVAL);
 -            goto fail;
 +    for (i = 0; i < nb_output_streams; i++) {
 +        OutputStream *ost = &output_streams[i];
 +
 +        if (!check_output_constraints(ist, ost) || !ost->encoding_needed)
 +            continue;
 +
 +        do_subtitle_out(output_files[ost->file_index].ctx, ost, ist, &subtitle, pkt->pts);
 +    }
 +
 +    avsubtitle_free(&subtitle);
 +    return ret;
 +}
 +
 +/* pkt = NULL means EOF (needed to flush decoder buffers) */
 +static int output_packet(InputStream *ist,
 +                         OutputStream *ost_table, int nb_ostreams,
 +                         const AVPacket *pkt)
 +{
 +    int ret = 0, i;
 +    int got_output;
 +    int64_t pkt_dts = AV_NOPTS_VALUE;
 +    int64_t pkt_pts = AV_NOPTS_VALUE;
 +
 +    AVPacket avpkt;
 +
 +    if (ist->next_pts == AV_NOPTS_VALUE)
 +        ist->next_pts = ist->pts;
 +
 +    if (pkt == NULL) {
 +        /* EOF handling */
 +        av_init_packet(&avpkt);
 +        avpkt.data = NULL;
 +        avpkt.size = 0;
 +        goto handle_eof;
 +    } else {
 +        avpkt = *pkt;
 +    }
 +
 +    if (pkt->dts != AV_NOPTS_VALUE) {
 +        if (ist->st->codec->codec_type != AVMEDIA_TYPE_VIDEO || !ist->decoding_needed)
 +            ist->next_pts = ist->pts = av_rescale_q(pkt->dts, ist->st->time_base, AV_TIME_BASE_Q);
 +        pkt_dts = av_rescale_q(pkt->dts, ist->st->time_base, AV_TIME_BASE_Q);
 +    }
 +    if(pkt->pts != AV_NOPTS_VALUE)
 +        pkt_pts = av_rescale_q(pkt->pts, ist->st->time_base, AV_TIME_BASE_Q);
 +
 +    // while we have more to decode or while the decoder did output something on EOF
 +    while (ist->decoding_needed && (avpkt.size > 0 || (!pkt && got_output))) {
 +    handle_eof:
 +
 +        ist->pts = ist->next_pts;
 +
 +        if (avpkt.size && avpkt.size != pkt->size) {
 +            av_log(NULL, ist->showed_multi_packet_warning ? AV_LOG_VERBOSE : AV_LOG_WARNING,
 +                   "Multiple frames in a packet from stream %d\n", pkt->stream_index);
 +            ist->showed_multi_packet_warning = 1;
 +        }
 +
 +        switch (ist->st->codec->codec_type) {
 +        case AVMEDIA_TYPE_AUDIO:
 +            ret = transcode_audio    (ist, &avpkt, &got_output);
 +            break;
 +        case AVMEDIA_TYPE_VIDEO:
 +            ret = transcode_video    (ist, &avpkt, &got_output, &pkt_pts, &pkt_dts);
 +            break;
 +        case AVMEDIA_TYPE_SUBTITLE:
 +            ret = transcode_subtitles(ist, &avpkt, &got_output);
 +            break;
 +        default:
 +            return -1;
 +        }
 +
 +        if (ret < 0)
 +            return ret;
 +
 +        avpkt.dts=
 +        avpkt.pts= AV_NOPTS_VALUE;
 +
 +        // touch data and size only if not EOF
 +        if (pkt) {
 +            if(ist->st->codec->codec_type != AVMEDIA_TYPE_AUDIO)
 +                ret = avpkt.size;
 +            avpkt.data += ret;
 +            avpkt.size -= ret;
 +        }
 +        if (!got_output) {
 +            continue;
          }
 -        nb_ostreams += os->nb_streams;
      }
 -    if (nb_stream_maps > 0 && nb_stream_maps != nb_ostreams) {
 -        fprintf(stderr, "Number of stream maps must match number of output streams\n");
 -        ret = AVERROR(EINVAL);
 -        goto fail;
 +
 +    /* handle stream copy */
 +    if (!ist->decoding_needed) {
 +        rate_emu_sleep(ist);
 +        ist->pts = ist->next_pts;
 +        switch (ist->st->codec->codec_type) {
 +        case AVMEDIA_TYPE_AUDIO:
 +            ist->next_pts += ((int64_t)AV_TIME_BASE * ist->st->codec->frame_size) /
 +                             ist->st->codec->sample_rate;
 +            break;
 +        case AVMEDIA_TYPE_VIDEO:
 +            if (pkt->duration) {
 +                ist->next_pts += av_rescale_q(pkt->duration, ist->st->time_base, AV_TIME_BASE_Q);
 +            } else if(ist->st->codec->time_base.num != 0) {
 +                int ticks= ist->st->parser ? ist->st->parser->repeat_pict + 1 : ist->st->codec->ticks_per_frame;
 +                ist->next_pts += ((int64_t)AV_TIME_BASE *
 +                                  ist->st->codec->time_base.num * ticks) /
 +                                  ist->st->codec->time_base.den;
 +            }
 +            break;
 +        }
      }
 +    for (i = 0; pkt && i < nb_ostreams; i++) {
 +        OutputStream *ost = &ost_table[i];
  
 -    /* Sanity check the mapping args -- do the input files & streams exist? */
 -    for(i=0;i<nb_stream_maps;i++) {
 -        int fi = stream_maps[i].file_index;
 -        int si = stream_maps[i].stream_index;
 +        if (!check_output_constraints(ist, ost) || ost->encoding_needed)
 +            continue;
  
 -        if (fi < 0 || fi > nb_input_files - 1 ||
 -            si < 0 || si > input_files[fi].nb_streams - 1) {
 -            fprintf(stderr,"Could not find input stream #%d.%d\n", fi, si);
 -            ret = AVERROR(EINVAL);
 -            goto fail;
 +        do_streamcopy(ist, ost, pkt);
 +    }
 +
 +    return 0;
 +}
 +
 +static void print_sdp(OutputFile *output_files, int n)
 +{
 +    char sdp[2048];
 +    int i;
 +    AVFormatContext **avc = av_malloc(sizeof(*avc) * n);
 +
 +    if (!avc)
 +        exit_program(1);
 +    for (i = 0; i < n; i++)
 +        avc[i] = output_files[i].ctx;
 +
 +    av_sdp_create(avc, n, sdp, sizeof(sdp));
 +    printf("SDP:\n%s\n", sdp);
 +    fflush(stdout);
 +    av_freep(&avc);
 +}
 +
 +static int init_input_stream(int ist_index, OutputStream *output_streams, int nb_output_streams,
 +                             char *error, int error_len)
 +{
 +    InputStream *ist = &input_streams[ist_index];
 +    if (ist->decoding_needed) {
 +        AVCodec *codec = ist->dec;
 +        if (!codec) {
 +            snprintf(error, error_len, "Decoder (codec %s) not found for input stream #%d:%d",
 +                    avcodec_get_name(ist->st->codec->codec_id), ist->file_index, ist->st->index);
 +            return AVERROR(EINVAL);
          }
 -        fi = stream_maps[i].sync_file_index;
 -        si = stream_maps[i].sync_stream_index;
 -        if (fi < 0 || fi > nb_input_files - 1 ||
 -            si < 0 || si > input_files[fi].nb_streams - 1) {
 -            fprintf(stderr,"Could not find sync stream #%d.%d\n", fi, si);
 -            ret = AVERROR(EINVAL);
 -            goto fail;
 +
 +        ist->dr1 = codec->capabilities & CODEC_CAP_DR1;
 +        if (codec->type == AVMEDIA_TYPE_VIDEO && ist->dr1) {
 +            ist->st->codec->get_buffer     = codec_get_buffer;
 +            ist->st->codec->release_buffer = codec_release_buffer;
 +            ist->st->codec->opaque         = ist;
 +        }
 +
 +        if (avcodec_open2(ist->st->codec, codec, &ist->opts) < 0) {
 +            snprintf(error, error_len, "Error while opening decoder for input stream #%d:%d",
 +                    ist->file_index, ist->st->index);
 +            return AVERROR(EINVAL);
          }
 +        assert_codec_experimental(ist->st->codec, 0);
 +        assert_avoptions(ist->opts);
      }
  
 -    ost_table = av_mallocz(sizeof(OutputStream *) * nb_ostreams);
 -    if (!ost_table)
 -        goto fail;
 -    n = 0;
 -    for(k=0;k<nb_output_files;k++) {
 -        os = output_files[k];
 -        for(i=0;i<os->nb_streams;i++,n++) {
 -            int found;
 -            ost = ost_table[n] = output_streams_for_file[k][i];
 -            if (nb_stream_maps > 0) {
 -                ost->source_index = input_files[stream_maps[n].file_index].ist_index +
 -                    stream_maps[n].stream_index;
 -
 -                /* Sanity check that the stream types match */
 -                if (input_streams[ost->source_index].st->codec->codec_type != ost->st->codec->codec_type) {
 -                    int i= ost->file_index;
 -                    av_dump_format(output_files[i], i, output_files[i]->filename, 1);
 -                    fprintf(stderr, "Codec type mismatch for mapping #%d.%d -> #%d.%d\n",
 -                        stream_maps[n].file_index, stream_maps[n].stream_index,
 -                        ost->file_index, ost->index);
 -                    exit_program(1);
 -                }
 +    ist->pts = ist->st->avg_frame_rate.num ? - ist->st->codec->has_b_frames * AV_TIME_BASE / av_q2d(ist->st->avg_frame_rate) : 0;
 +    ist->next_pts = AV_NOPTS_VALUE;
 +    ist->is_start = 1;
  
 -            } else {
 -                int best_nb_frames=-1;
 -                /* get corresponding input stream index : we select the first one with the right type */
 -                found = 0;
 -                for (j = 0; j < nb_input_streams; j++) {
 -                    int skip=0;
 -                    ist = &input_streams[j];
 -                    if(opt_programid){
 -                        int pi,si;
 -                        AVFormatContext *f = input_files[ist->file_index].ctx;
 -                        skip=1;
 -                        for(pi=0; pi<f->nb_programs; pi++){
 -                            AVProgram *p= f->programs[pi];
 -                            if(p->id == opt_programid)
 -                                for(si=0; si<p->nb_stream_indexes; si++){
 -                                    if(f->streams[ p->stream_index[si] ] == ist->st)
 -                                        skip=0;
 -                                }
 -                        }
 -                    }
 -                    if (ist->discard && ist->st->discard != AVDISCARD_ALL && !skip &&
 -                        ist->st->codec->codec_type == ost->st->codec->codec_type) {
 -                        if(best_nb_frames < ist->st->codec_info_nb_frames){
 -                            best_nb_frames= ist->st->codec_info_nb_frames;
 -                            ost->source_index = j;
 -                            found = 1;
 -                        }
 -                    }
 -                }
 +    return 0;
 +}
  
 -                if (!found) {
 -                    if(! opt_programid) {
 -                        /* try again and reuse existing stream */
 -                        for (j = 0; j < nb_input_streams; j++) {
 -                            ist = &input_streams[j];
 -                            if (   ist->st->codec->codec_type == ost->st->codec->codec_type
 -                                && ist->st->discard != AVDISCARD_ALL) {
 -                                ost->source_index = j;
 -                                found = 1;
 -                            }
 -                        }
 -                    }
 -                    if (!found) {
 -                        int i= ost->file_index;
 -                        av_dump_format(output_files[i], i, output_files[i]->filename, 1);
 -                        fprintf(stderr, "Could not find input stream matching output stream #%d.%d\n",
 -                                ost->file_index, ost->index);
 -                        exit_program(1);
 -                    }
 -                }
 -            }
 -            ist = &input_streams[ost->source_index];
 -            ist->discard = 0;
 -            ost->sync_ist = (nb_stream_maps > 0) ?
 -                &input_streams[input_files[stream_maps[n].sync_file_index].ist_index +
 -                         stream_maps[n].sync_stream_index] : ist;
 +static int transcode_init(OutputFile *output_files, int nb_output_files,
 +                          InputFile  *input_files,  int nb_input_files)
 +{
 +    int ret = 0, i, j, k;
 +    AVFormatContext *oc;
 +    AVCodecContext *codec, *icodec;
 +    OutputStream *ost;
 +    InputStream *ist;
 +    char error[1024];
 +    int want_sdp = 1;
 +
 +    /* init framerate emulation */
 +    for (i = 0; i < nb_input_files; i++) {
 +        InputFile *ifile = &input_files[i];
 +        if (ifile->rate_emu)
 +            for (j = 0; j < ifile->nb_streams; j++)
 +                input_streams[j + ifile->ist_index].start = av_gettime();
 +    }
 +
 +    /* output stream init */
 +    for (i = 0; i < nb_output_files; i++) {
 +        oc = output_files[i].ctx;
 +        if (!oc->nb_streams && !(oc->oformat->flags & AVFMT_NOSTREAMS)) {
 +            av_dump_format(oc, i, oc->filename, 1);
 +            av_log(NULL, AV_LOG_ERROR, "Output file #%d does not contain any stream\n", i);
 +            return AVERROR(EINVAL);
          }
      }
  
diff --cc ffplay.c
index c55b008ee5cd325d8be236b34999dafb3b61b0d8,6dbf140135a77ba2d8e7a755783df18002b902c2..4bb1e050bf9fdb12f38751b82b04ce953b7962cb
+++ b/ffplay.c
@@@ -99,10 -97,9 +99,10 @@@ typedef struct PacketQueue 
  #define SUBPICTURE_QUEUE_SIZE 4
  
  typedef struct VideoPicture {
-     double pts;                                  ///<presentation time stamp for this picture
-     double duration;                             ///<expected duration of the frame
-     int64_t pos;                                 ///<byte position in file
+     double pts;                                  ///< presentation time stamp for this picture
 -    double target_clock;                         ///< av_gettime() time at which this should be displayed ideally
++    double duration;                             ///< expected duration of the frame
+     int64_t pos;                                 ///< byte position in file
 +    int skip;
      SDL_Overlay *bmp;
      int width, height; /* source height & width */
      int allocated;
@@@ -202,12 -185,8 +202,12 @@@ typedef struct VideoState 
  
      double frame_timer;
      double frame_last_pts;
 -    double frame_last_delay;
 +    double frame_last_duration;
 +    double frame_last_dropped_pts;
 +    double frame_last_returned_time;
 +    double frame_last_filter_delay;
 +    int64_t frame_last_dropped_pos;
-     double video_clock;                          ///<pts of last decoded frame / predicted pts of next decoded frame
+     double video_clock;                          ///< pts of last decoded frame / predicted pts of next decoded frame
      int video_stream;
      AVStream *video_st;
      PacketQueue videoq;
      struct SwsContext *img_convert_ctx;
  #endif
  
 -    //    QETimer *video_timer;
      char filename[1024];
      int width, height, xleft, ytop;
 -
 -    PtsCorrectionContext pts_ctx;
 +    int step;
  
  #if CONFIG_AVFILTER
-     AVFilterContext *out_video_filter;          ///<the last filter in the video chain
+     AVFilterContext *out_video_filter;          ///< the last filter in the video chain
  #endif
  
 -    float skip_frames;
 -    float skip_frames_index;
      int refresh;
  } VideoState;
  
@@@ -270,14 -257,10 +270,13 @@@ static int decoder_reorder_pts = -1
  static int autoexit;
  static int exit_on_keydown;
  static int exit_on_mousedown;
- static int loop=1;
- static int framedrop=-1;
+ static int loop = 1;
 -static int framedrop = 1;
 -
++static int framedrop = -1;
 +static enum ShowMode show_mode = SHOW_MODE_NONE;
 +static const char *audio_codec_name;
 +static const char *subtitle_codec_name;
 +static const char *video_codec_name;
- static int rdftspeed=20;
+ static int rdftspeed = 20;
  #if CONFIG_AVFILTER
  static char *vfilters = NULL;
  #endif
@@@ -299,37 -283,7 +298,37 @@@ void av_noreturn exit_program(int ret
      exit(ret);
  }
  
 -static int packet_queue_put(PacketQueue *q, AVPacket *pkt);
 +static int packet_queue_put(PacketQueue *q, AVPacket *pkt)
 +{
 +    AVPacketList *pkt1;
 +
 +    /* duplicate the packet */
-     if (pkt!=&flush_pkt && av_dup_packet(pkt) < 0)
++    if (pkt != &flush_pkt && av_dup_packet(pkt) < 0)
 +        return -1;
 +
 +    pkt1 = av_malloc(sizeof(AVPacketList));
 +    if (!pkt1)
 +        return -1;
 +    pkt1->pkt = *pkt;
 +    pkt1->next = NULL;
 +
 +
 +    SDL_LockMutex(q->mutex);
 +
 +    if (!q->last_pkt)
 +
 +        q->first_pkt = pkt1;
 +    else
 +        q->last_pkt->next = pkt1;
 +    q->last_pkt = pkt1;
 +    q->nb_packets++;
 +    q->size += pkt1->pkt.size + sizeof(*pkt1);
 +    /* XXX: should duplicate packet data in DV case */
 +    SDL_CondSignal(q->cond);
 +
 +    SDL_UnlockMutex(q->mutex);
 +    return 0;
 +}
  
  /* packet queue handling */
  static void packet_queue_init(PacketQueue *q)
@@@ -742,43 -742,43 +741,43 @@@ static void video_audio_display(VideoSt
      int16_t time_diff;
      int rdft_bits, nb_freq;
  
-     for(rdft_bits=1; (1<<rdft_bits)<2*s->height; rdft_bits++)
+     for (rdft_bits = 1; (1 << rdft_bits) < 2 * s->height; rdft_bits++)
          ;
-     nb_freq= 1<<(rdft_bits-1);
+     nb_freq = 1 << (rdft_bits - 1);
  
      /* compute display index : center on currently output samples */
 -    channels = s->audio_st->codec->channels;
 +    channels = s->audio_tgt_channels;
      nb_display_channels = channels;
      if (!s->paused) {
 -        int data_used = s->show_audio == 1 ? s->width : (2 * nb_freq);
 +        int data_used= s->show_mode == SHOW_MODE_WAVES ? s->width : (2*nb_freq);
          n = 2 * channels;
 -        delay = audio_write_get_buf_size(s);
 +        delay = s->audio_write_buf_size;
          delay /= n;
  
          /* to be more precise, we take into account the time spent since
             the last buffer computation */
          if (audio_callback_time) {
              time_diff = av_gettime() - audio_callback_time;
 -            delay -= (time_diff * s->audio_st->codec->sample_rate) / 1000000;
 +            delay -= (time_diff * s->audio_tgt_freq) / 1000000;
          }
  
-         delay += 2*data_used;
+         delay += 2 * data_used;
          if (delay < data_used)
              delay = data_used;
  
          i_start= x = compute_mod(s->sample_array_index - delay * channels, SAMPLE_ARRAY_SIZE);
 -        if (s->show_audio == 1) {
 +        if (s->show_mode == SHOW_MODE_WAVES) {
-             h= INT_MIN;
-             for(i=0; i<1000; i+=channels){
-                 int idx= (SAMPLE_ARRAY_SIZE + x - i) % SAMPLE_ARRAY_SIZE;
-                 int a= s->sample_array[idx];
-                 int b= s->sample_array[(idx + 4*channels)%SAMPLE_ARRAY_SIZE];
-                 int c= s->sample_array[(idx + 5*channels)%SAMPLE_ARRAY_SIZE];
-                 int d= s->sample_array[(idx + 9*channels)%SAMPLE_ARRAY_SIZE];
-                 int score= a-d;
-                 if(h<score && (b^c)<0){
-                     h= score;
-                     i_start= idx;
+             h = INT_MIN;
+             for (i = 0; i < 1000; i += channels) {
+                 int idx = (SAMPLE_ARRAY_SIZE + x - i) % SAMPLE_ARRAY_SIZE;
+                 int a = s->sample_array[idx];
+                 int b = s->sample_array[(idx + 4 * channels) % SAMPLE_ARRAY_SIZE];
+                 int c = s->sample_array[(idx + 5 * channels) % SAMPLE_ARRAY_SIZE];
+                 int d = s->sample_array[(idx + 9 * channels) % SAMPLE_ARRAY_SIZE];
+                 int score = a - d;
+                 if (h < score && (b ^ c) < 0) {
+                     h = score;
+                     i_start = idx;
                  }
              }
          }
      }
  }
  
 -static int video_open(VideoState *is)
 +static void stream_close(VideoState *is)
 +{
 +    VideoPicture *vp;
 +    int i;
 +    /* XXX: use a special url_shutdown call to abort parse cleanly */
 +    is->abort_request = 1;
 +    SDL_WaitThread(is->read_tid, NULL);
 +    SDL_WaitThread(is->refresh_tid, NULL);
 +
 +    /* free all pictures */
-     for(i=0;i<VIDEO_PICTURE_QUEUE_SIZE; i++) {
++    for (i = 0; i < VIDEO_PICTURE_QUEUE_SIZE; i++) {
 +        vp = &is->pictq[i];
 +#if CONFIG_AVFILTER
 +        if (vp->picref) {
 +            avfilter_unref_buffer(vp->picref);
 +            vp->picref = NULL;
 +        }
 +#endif
 +        if (vp->bmp) {
 +            SDL_FreeYUVOverlay(vp->bmp);
 +            vp->bmp = NULL;
 +        }
 +    }
 +    SDL_DestroyMutex(is->pictq_mutex);
 +    SDL_DestroyCond(is->pictq_cond);
 +    SDL_DestroyMutex(is->subpq_mutex);
 +    SDL_DestroyCond(is->subpq_cond);
 +#if !CONFIG_AVFILTER
 +    if (is->img_convert_ctx)
 +        sws_freeContext(is->img_convert_ctx);
 +#endif
 +    av_free(is);
 +}
 +
 +static void do_exit(VideoState *is)
 +{
 +    if (is) {
 +        stream_close(is);
 +    }
 +    av_lockmgr_register(NULL);
 +    uninit_opts();
 +#if CONFIG_AVFILTER
 +    avfilter_uninit();
 +#endif
 +    avformat_network_deinit();
 +    if (show_status)
 +        printf("\n");
 +    SDL_Quit();
 +    av_log(NULL, AV_LOG_QUIET, "%s", "");
 +    exit(0);
 +}
 +
- static int video_open(VideoState *is, int force_set_video_mode){
-     int flags = SDL_HWSURFACE|SDL_ASYNCBLIT|SDL_HWACCEL;
++static int video_open(VideoState *is, int force_set_video_mode)
+ {
+     int flags = SDL_HWSURFACE | SDL_ASYNCBLIT | SDL_HWACCEL;
      int w,h;
  
-     if(is_full_screen) flags |= SDL_FULLSCREEN;
-     else               flags |= SDL_RESIZABLE;
+     if (is_full_screen) flags |= SDL_FULLSCREEN;
+     else                flags |= SDL_RESIZABLE;
  
      if (is_full_screen && fs_screen_width) {
          w = fs_screen_width;
          w = 640;
          h = 480;
      }
-     if(screen && is->width == screen->w && screen->w == w
+     if (screen && is->width == screen->w && screen->w == w
 -       && is->height== screen->h && screen->h == h)
 +       && is->height== screen->h && screen->h == h && !force_set_video_mode)
          return 0;
 -
 -#if defined(__APPLE__) && !SDL_VERSION_ATLEAST(1, 2, 14)
 -    /* setting bits_per_pixel = 0 or 32 causes blank video on OS X and older SDL */
 -    screen = SDL_SetVideoMode(w, h, 24, flags);
 -#else
      screen = SDL_SetVideoMode(w, h, 0, flags);
 -#endif
      if (!screen) {
          fprintf(stderr, "SDL: could not set video mode - exiting\n");
 -        return -1;
 +        do_exit(is);
      }
      if (!window_title)
          window_title = input_filename;
  /* display the current picture, if any */
  static void video_display(VideoState *is)
  {
-     if(!screen)
+     if (!screen)
 -        video_open(cur_stream);
 -    if (is->audio_st && is->show_audio)
 +        video_open(is, 0);
 +    if (is->audio_st && is->show_mode != SHOW_MODE_VIDEO)
          video_audio_display(is);
      else if (is->video_st)
          video_image_display(is);
@@@ -988,12 -943,11 +988,12 @@@ static int refresh_thread(void *opaque
          SDL_Event event;
          event.type = FF_REFRESH_EVENT;
          event.user.data1 = opaque;
-         if(!is->refresh){
-             is->refresh=1;
+         if (!is->refresh) {
+             is->refresh = 1;
              SDL_PushEvent(&event);
          }
 -        usleep(is->audio_st && is->show_audio ? rdftspeed * 1000 : 5000); // FIXME ideally we should wait the correct time but SDLs event passing is so slow it would be silly
 +        //FIXME ideally we should wait the correct time but SDLs event passing is so slow it would be silly
 +        usleep(is->audio_st && is->show_mode != SHOW_MODE_VIDEO ? rdftspeed*1000 : 5000);
      }
      return 0;
  }
@@@ -1134,53 -1085,37 +1134,53 @@@ static void video_refresh(void *opaque
      if (is->video_st) {
  retry:
          if (is->pictq_size == 0) {
-             //nothing to do, no picture to display in the que
 +            SDL_LockMutex(is->pictq_mutex);
 +            if (is->frame_last_dropped_pts != AV_NOPTS_VALUE && is->frame_last_dropped_pts > is->frame_last_pts) {
 +                update_video_pts(is, is->frame_last_dropped_pts, is->frame_last_dropped_pos);
 +                is->frame_last_dropped_pts = AV_NOPTS_VALUE;
 +            }
 +            SDL_UnlockMutex(is->pictq_mutex);
+             // nothing to do, no picture to display in the que
          } else {
 -            double time = av_gettime() / 1000000.0;
 -            double next_target;
 +            double last_duration, duration, delay;
              /* dequeue the picture */
              vp = &is->pictq[is->pictq_rindex];
  
 -            if (time < vp->target_clock)
 +            if (vp->skip) {
 +                pictq_next_picture(is);
 +                goto retry;
 +            }
 +
 +            /* compute nominal last_duration */
 +            last_duration = vp->pts - is->frame_last_pts;
 +            if (last_duration > 0 && last_duration < 10.0) {
 +                /* if duration of the last frame was sane, update last_duration in video state */
 +                is->frame_last_duration = last_duration;
 +            }
 +            delay = compute_target_delay(is->frame_last_duration, is);
 +
 +            time= av_gettime()/1000000.0;
-             if(time < is->frame_timer + delay)
++            if (time < is->frame_timer + delay)
                  return;
 -            /* update current video pts */
 -            is->video_current_pts = vp->pts;
 -            is->video_current_pts_drift = is->video_current_pts - time;
 -            is->video_current_pos = vp->pos;
 +
 +            if (delay > 0)
 +                is->frame_timer += delay * FFMAX(1, floor((time-is->frame_timer) / delay));
 +
 +            SDL_LockMutex(is->pictq_mutex);
 +            update_video_pts(is, vp->pts, vp->pos);
 +            SDL_UnlockMutex(is->pictq_mutex);
 +
-             if(is->pictq_size > 1) {
-                  VideoPicture *nextvp= &is->pictq[(is->pictq_rindex+1)%VIDEO_PICTURE_QUEUE_SIZE];
-                  duration = nextvp->pts - vp->pts; // More accurate this way, 1/time_base is often not reflecting FPS
+             if (is->pictq_size > 1) {
+                 VideoPicture *nextvp = &is->pictq[(is->pictq_rindex + 1) % VIDEO_PICTURE_QUEUE_SIZE];
 -                assert(nextvp->target_clock >= vp->target_clock);
 -                next_target= nextvp->target_clock;
++                duration = nextvp->pts - vp->pts; // More accurate this way, 1/time_base is often not reflecting FPS
              } else {
-                  duration = vp->duration;
 -                next_target = vp->target_clock + is->video_clock - vp->pts; // FIXME pass durations cleanly
++                duration = vp->duration;
              }
 -            if (framedrop && time > next_target) {
 -                is->skip_frames *= 1.0 + FRAME_SKIP_FACTOR;
 -                if (is->pictq_size > 1 || time > next_target + 0.5) {
 -                    /* update queue size and signal for next picture */
 -                    if (++is->pictq_rindex == VIDEO_PICTURE_QUEUE_SIZE)
 -                        is->pictq_rindex = 0;
 -
 -                    SDL_LockMutex(is->pictq_mutex);
 -                    is->pictq_size--;
 -                    SDL_CondSignal(is->pictq_cond);
 -                    SDL_UnlockMutex(is->pictq_mutex);
 +
 +            if((framedrop>0 || (framedrop && is->audio_st)) && time > is->frame_timer + duration){
 +                if(is->pictq_size > 1){
 +                    is->frame_drops_late++;
 +                    pictq_next_picture(is);
                      goto retry;
                  }
              }
@@@ -1424,8 -1394,16 +1424,8 @@@ static int queue_picture(VideoState *is
          pict.linesize[2] = vp->bmp->pitches[1];
  
  #if CONFIG_AVFILTER
-         //FIXME use direct rendering
 -        pict_src.data[0] = src_frame->data[0];
 -        pict_src.data[1] = src_frame->data[1];
 -        pict_src.data[2] = src_frame->data[2];
 -
 -        pict_src.linesize[0] = src_frame->linesize[0];
 -        pict_src.linesize[1] = src_frame->linesize[1];
 -        pict_src.linesize[2] = src_frame->linesize[2];
 -
+         // FIXME use direct rendering
 -        av_picture_copy(&pict, &pict_src,
 +        av_picture_copy(&pict, (AVPicture *)src_frame,
                          vp->pix_fmt, vp->width, vp->height);
  #else
          sws_flags = av_get_int(sws_opts, "sws_flags", NULL);
@@@ -1467,9 -1472,9 +1467,9 @@@ static int get_video_frame(VideoState *
          avcodec_flush_buffers(is->video_st->codec);
  
          SDL_LockMutex(is->pictq_mutex);
-         //Make sure there are no long delay timers (ideally we should just flush the que but thats harder)
+         // Make sure there are no long delay timers (ideally we should just flush the que but thats harder)
          for (i = 0; i < VIDEO_PICTURE_QUEUE_SIZE; i++) {
 -            is->pictq[i].target_clock= 0;
 +            is->pictq[i].skip = 1;
          }
          while (is->pictq_size && !is->videoq.abort_request) {
              SDL_CondWait(is->pictq_cond, is->pictq_mutex);
@@@ -1566,17 -1548,14 +1566,17 @@@ static int input_get_buffer(AVCodecCont
      edge = codec->flags & CODEC_FLAG_EMU_EDGE ? 0 : avcodec_get_edge_width();
      w += edge << 1;
      h += edge << 1;
 -
 +    if (codec->pix_fmt != ctx->outputs[0]->format) {
 +        av_log(codec, AV_LOG_ERROR, "Pixel format mismatches %d %d\n", codec->pix_fmt, ctx->outputs[0]->format);
 +        return -1;
 +    }
-     if(!(ref = avfilter_get_video_buffer(ctx->outputs[0], perms, w, h)))
+     if (!(ref = avfilter_get_video_buffer(ctx->outputs[0], perms, w, h)))
          return -1;
  
-     pixel_size = av_pix_fmt_descriptors[ref->format].comp[0].step_minus1+1;
+     pixel_size = av_pix_fmt_descriptors[ref->format].comp[0].step_minus1 + 1;
      ref->video->w = codec->width;
      ref->video->h = codec->height;
-     for(i = 0; i < 4; i ++) {
+     for (i = 0; i < 4; i ++) {
          unsigned hshift = (i == 1 || i == 2) ? av_pix_fmt_descriptors[ref->format].log2_chroma_w : 0;
          unsigned vshift = (i == 1 || i == 2) ? av_pix_fmt_descriptors[ref->format].log2_chroma_h : 0;
  
@@@ -1630,9 -1609,7 +1630,8 @@@ static int input_init(AVFilterContext *
      priv->is = opaque;
      codec    = priv->is->video_st->codec;
      codec->opaque = ctx;
-     if((codec->codec->capabilities & CODEC_CAP_DR1)
-     ) {
+     if (codec->codec->capabilities & CODEC_CAP_DR1) {
 +        av_assert0(codec->flags & CODEC_FLAG_EMU_EDGE);
          priv->use_dr1 = 1;
          codec->get_buffer     = input_get_buffer;
          codec->release_buffer = input_release_buffer;
@@@ -1664,7 -1641,7 +1663,7 @@@ static int input_request_frame(AVFilter
      if (ret < 0)
          return -1;
  
-     if(priv->use_dr1 && priv->frame->opaque) {
 -    if (priv->use_dr1) {
++    if (priv->use_dr1 && priv->frame->opaque) {
          picref = avfilter_ref_buffer(priv->frame->opaque, ~0);
      } else {
          picref = avfilter_get_video_buffer(link, AV_PERM_WRITE, link->w, link->h);
@@@ -1741,21 -1715,13 +1740,21 @@@ static int configure_video_filters(AVFi
      if ((ret = avfilter_graph_create_filter(&filt_src, &input_filter, "src",
                                              NULL, is, graph)) < 0)
          return ret;
 -    if ((ret = avfilter_graph_create_filter(&filt_out, &ffsink, "out",
 -                                            NULL, &ffsink_ctx, graph)) < 0)
 +#if FF_API_OLD_VSINK_API
 +    ret = avfilter_graph_create_filter(&filt_out, avfilter_get_by_name("buffersink"), "out",
 +                                       NULL, pix_fmts, graph);
 +#else
 +    buffersink_params->pixel_fmts = pix_fmts;
 +    ret = avfilter_graph_create_filter(&filt_out, avfilter_get_by_name("buffersink"), "out",
 +                                       NULL, buffersink_params, graph);
 +#endif
 +    av_freep(&buffersink_params);
 +    if (ret < 0)
          return ret;
  
-     if(vfilters) {
+     if (vfilters) {
 -        AVFilterInOut *outputs = av_malloc(sizeof(AVFilterInOut));
 -        AVFilterInOut *inputs  = av_malloc(sizeof(AVFilterInOut));
 +        AVFilterInOut *outputs = avfilter_inout_alloc();
 +        AVFilterInOut *inputs  = avfilter_inout_alloc();
  
          outputs->name    = av_strdup("in");
          outputs->filter_ctx = filt_src;
  static int video_thread(void *arg)
  {
      VideoState *is = arg;
-     AVFrame *frame= avcodec_alloc_frame();
+     AVFrame *frame = avcodec_alloc_frame();
 -    int64_t pts_int;
 +    int64_t pts_int = AV_NOPTS_VALUE, pos = -1;
      double pts;
      int ret;
  
          }
  #else
          ret = get_video_frame(is, frame, &pts_int, &pkt);
 +        pos = pkt.pos;
 +        av_free_packet(&pkt);
  #endif
  
-         if (ret < 0) goto the_end;
+         if (ret < 0)
+             goto the_end;
  
 -        if (!ret)
 +        is->frame_last_filter_delay = av_gettime() / 1000000.0 - is->frame_last_returned_time;
 +        if (fabs(is->frame_last_filter_delay) > AV_NOSYNC_THRESHOLD / 10.0)
 +            is->frame_last_filter_delay = 0;
 +
 +#if CONFIG_AVFILTER
 +        if (!picref)
              continue;
 +#endif
  
-         pts = pts_int*av_q2d(is->video_st->time_base);
+         pts = pts_int * av_q2d(is->video_st->time_base);
  
 -#if CONFIG_AVFILTER
 -        ret = output_picture2(is, frame, pts, pos);
 -#else
 -        ret = output_picture2(is, frame, pts,  pkt.pos);
 -        av_free_packet(&pkt);
 -#endif
 +        ret = queue_picture(is, frame, pts, pos);
 +
          if (ret < 0)
              goto the_end;
  
@@@ -2044,10 -2009,8 +2044,10 @@@ static int audio_decode_frame(VideoStat
  {
      AVPacket *pkt_temp = &is->audio_pkt_temp;
      AVPacket *pkt = &is->audio_pkt;
-     AVCodecContext *dec= is->audio_st->codec;
+     AVCodecContext *dec = is->audio_st->codec;
 -    int n, len1, data_size, got_frame;
 +    int len1, len2, data_size, resampled_data_size;
 +    int64_t dec_channel_layout;
 +    int got_frame;
      double pts;
      int new_packet = 0;
      int flush_complete = 0;
@@@ -2226,46 -2176,23 +2226,46 @@@ static int stream_component_open(VideoS
          return -1;
      avctx = ic->streams[stream_index]->codec;
  
 -    opts = filter_codec_opts(codec_opts, avctx->codec_id, ic, ic->streams[stream_index]);
 -
      codec = avcodec_find_decoder(avctx->codec_id);
 -    avctx->debug_mv          = debug_mv;
 -    avctx->debug             = debug;
 +    opts = filter_codec_opts(codec_opts, codec, ic, ic->streams[stream_index]);
 +
 +    switch(avctx->codec_type){
 +        case AVMEDIA_TYPE_AUDIO   : if(audio_codec_name   ) codec= avcodec_find_decoder_by_name(   audio_codec_name); break;
 +        case AVMEDIA_TYPE_SUBTITLE: if(subtitle_codec_name) codec= avcodec_find_decoder_by_name(subtitle_codec_name); break;
 +        case AVMEDIA_TYPE_VIDEO   : if(video_codec_name   ) codec= avcodec_find_decoder_by_name(   video_codec_name); break;
 +    }
 +    if (!codec)
 +        return -1;
 +
-     avctx->workaround_bugs = workaround_bugs;
-     avctx->lowres = lowres;
+     avctx->workaround_bugs   = workaround_bugs;
+     avctx->lowres            = lowres;
 +    if(avctx->lowres > codec->max_lowres){
 +        av_log(avctx, AV_LOG_WARNING, "The maximum value for lowres supported by the decoder is %d\n",
 +                codec->max_lowres);
 +        avctx->lowres= codec->max_lowres;
 +    }
-     if(avctx->lowres) avctx->flags |= CODEC_FLAG_EMU_EDGE;
-     avctx->idct_algo= idct;
-     if(fast) avctx->flags2 |= CODEC_FLAG2_FAST;
-     avctx->skip_frame= skip_frame;
-     avctx->skip_idct= skip_idct;
-     avctx->skip_loop_filter= skip_loop_filter;
-     avctx->error_recognition= error_recognition;
-     avctx->error_concealment= error_concealment;
+     avctx->idct_algo         = idct;
+     avctx->skip_frame        = skip_frame;
+     avctx->skip_idct         = skip_idct;
+     avctx->skip_loop_filter  = skip_loop_filter;
+     avctx->error_recognition = error_recognition;
+     avctx->error_concealment = error_concealment;
 -    avctx->thread_count      = thread_count;
  
 -    if (lowres) avctx->flags  |= CODEC_FLAG_EMU_EDGE;
++    if(avctx->lowres) avctx->flags |= CODEC_FLAG_EMU_EDGE;
+     if (fast)   avctx->flags2 |= CODEC_FLAG2_FAST;
 +    if(codec->capabilities & CODEC_CAP_DR1)
 +        avctx->flags |= CODEC_FLAG_EMU_EDGE;
 +
 +    if (avctx->codec_type == AVMEDIA_TYPE_AUDIO) {
 +        wanted_channel_layout = (avctx->channel_layout && avctx->channels == av_get_channel_layout_nb_channels(avctx->channels)) ? avctx->channel_layout : av_get_default_channel_layout(avctx->channels);
 +        wanted_channel_layout &= ~AV_CH_LAYOUT_STEREO_DOWNMIX;
 +        wanted_spec.channels = av_get_channel_layout_nb_channels(wanted_channel_layout);
 +        wanted_spec.freq = avctx->sample_rate;
 +        if (wanted_spec.freq <= 0 || wanted_spec.channels <= 0) {
 +            fprintf(stderr, "Invalid sample rate or channel count!\n");
 +            return -1;
 +        }
 +    }
  
      if (!codec ||
          avcodec_open2(avctx, codec, &opts) < 0)
@@@ -2482,11 -2402,11 +2482,11 @@@ static int read_thread(void *arg
          av_dict_free(&opts[i]);
      av_freep(&opts);
  
-     if(ic->pb)
-         ic->pb->eof_reached= 0; //FIXME hack, ffplay maybe should not use url_feof() to test for the end
+     if (ic->pb)
 -        ic->pb->eof_reached = 0; // FIXME hack, avplay maybe should not use url_feof() to test for the end
++        ic->pb->eof_reached = 0; // FIXME hack, ffplay maybe should not use url_feof() to test for the end
  
-     if(seek_by_bytes<0)
-         seek_by_bytes= !!(ic->iformat->flags & AVFMT_TS_DISCONT);
+     if (seek_by_bytes < 0)
+         seek_by_bytes = !!(ic->iformat->flags & AVFMT_TS_DISCONT);
  
      /* if seeking requested, we execute it */
      if (start_time != AV_NOPTS_VALUE) {
          stream_component_open(is, st_index[AVMEDIA_TYPE_AUDIO]);
      }
  
-     ret=-1;
+     ret = -1;
      if (st_index[AVMEDIA_TYPE_VIDEO] >= 0) {
-         ret= stream_component_open(is, st_index[AVMEDIA_TYPE_VIDEO]);
+         ret = stream_component_open(is, st_index[AVMEDIA_TYPE_VIDEO]);
      }
      is->refresh_tid = SDL_CreateThread(refresh_thread, is);
 -    if (ret < 0) {
 -        if (!display_disable)
 -            is->show_audio = 2;
 -    }
 +    if (is->show_mode == SHOW_MODE_NONE)
 +        is->show_mode = ret >= 0 ? SHOW_MODE_VIDEO : SHOW_MODE_RDFT;
  
      if (st_index[AVMEDIA_TYPE_SUBTITLE] >= 0) {
          stream_component_open(is, st_index[AVMEDIA_TYPE_SUBTITLE]);
                  packet_queue_put(&is->audioq, pkt);
              }
              SDL_Delay(10);
-             if(is->audioq.size + is->videoq.size + is->subtitleq.size ==0){
-                 if(loop!=1 && (!loop || --loop)){
+             if (is->audioq.size + is->videoq.size + is->subtitleq.size == 0) {
+                 if (loop != 1 && (!loop || --loop)) {
 -                    stream_seek(cur_stream, start_time != AV_NOPTS_VALUE ? start_time : 0, 0, 0);
 +                    stream_seek(is, start_time != AV_NOPTS_VALUE ? start_time : 0, 0, 0);
-                 }else if(autoexit){
-                     ret=AVERROR_EOF;
+                 } else if (autoexit) {
+                     ret = AVERROR_EOF;
                      goto fail;
                  }
              }
          }
          ret = av_read_frame(ic, pkt);
          if (ret < 0) {
 -            if (ret == AVERROR_EOF || (ic->pb && ic->pb->eof_reached))
 +            if (ret == AVERROR_EOF || url_feof(ic->pb))
-                 eof=1;
+                 eof = 1;
              if (ic->pb && ic->pb->error)
                  break;
              SDL_Delay(100); /* wait for user event */
@@@ -2704,14 -2625,14 +2704,14 @@@ static VideoState *stream_open(const ch
  
      /* start video display */
      is->pictq_mutex = SDL_CreateMutex();
-     is->pictq_cond = SDL_CreateCond();
+     is->pictq_cond  = SDL_CreateCond();
  
      is->subpq_mutex = SDL_CreateMutex();
-     is->subpq_cond = SDL_CreateCond();
+     is->subpq_cond  = SDL_CreateCond();
  
      is->av_sync_type = av_sync_type;
-     is->read_tid = SDL_CreateThread(read_thread, is);
 -    is->parse_tid    = SDL_CreateThread(decode_thread, is);
 -    if (!is->parse_tid) {
++    is->read_tid     = SDL_CreateThread(read_thread, is);
 +    if (!is->read_tid) {
          av_free(is);
          return NULL;
      }
@@@ -2811,48 -2736,45 +2811,48 @@@ static void event_loop(VideoState *cur_
      SDL_Event event;
      double incr, pos, frac;
  
-     for(;;) {
+     for (;;) {
          double x;
          SDL_WaitEvent(&event);
-         switch(event.type) {
+         switch (event.type) {
          case SDL_KEYDOWN:
              if (exit_on_keydown) {
 -                do_exit();
 +                do_exit(cur_stream);
                  break;
              }
-             switch(event.key.keysym.sym) {
+             switch (event.key.keysym.sym) {
              case SDLK_ESCAPE:
              case SDLK_q:
 -                do_exit();
 +                do_exit(cur_stream);
                  break;
              case SDLK_f:
 -                toggle_full_screen();
 +                toggle_full_screen(cur_stream);
                  break;
              case SDLK_p:
              case SDLK_SPACE:
 -                toggle_pause();
 +                toggle_pause(cur_stream);
                  break;
-             case SDLK_s: //S: Step to next frame
+             case SDLK_s: // S: Step to next frame
 -                step_to_next_frame();
 +                step_to_next_frame(cur_stream);
                  break;
              case SDLK_a:
 -                if (cur_stream)
 -                    stream_cycle_channel(cur_stream, AVMEDIA_TYPE_AUDIO);
 +                stream_cycle_channel(cur_stream, AVMEDIA_TYPE_AUDIO);
                  break;
              case SDLK_v:
 -                if (cur_stream)
 -                    stream_cycle_channel(cur_stream, AVMEDIA_TYPE_VIDEO);
 +                stream_cycle_channel(cur_stream, AVMEDIA_TYPE_VIDEO);
                  break;
              case SDLK_t:
 -                if (cur_stream)
 -                    stream_cycle_channel(cur_stream, AVMEDIA_TYPE_SUBTITLE);
 +                stream_cycle_channel(cur_stream, AVMEDIA_TYPE_SUBTITLE);
                  break;
              case SDLK_w:
 -                toggle_audio_display();
 +                toggle_audio_display(cur_stream);
                  break;
 +            case SDLK_PAGEUP:
 +                incr = 600.0;
 +                goto do_seek;
 +            case SDLK_PAGEDOWN:
 +                incr = -600.0;
 +                goto do_seek;
              case SDLK_LEFT:
                  incr = -10.0;
                  goto do_seek;
              case SDLK_DOWN:
                  incr = -60.0;
              do_seek:
-                 if (seek_by_bytes) {
-                     if (cur_stream->video_stream >= 0 && cur_stream->video_current_pos>=0){
-                         pos= cur_stream->video_current_pos;
-                     }else if(cur_stream->audio_stream >= 0 && cur_stream->audio_pkt.pos>=0){
-                         pos= cur_stream->audio_pkt.pos;
-                     }else
-                         pos = avio_tell(cur_stream->ic->pb);
-                     if (cur_stream->ic->bit_rate)
-                         incr *= cur_stream->ic->bit_rate / 8.0;
-                     else
-                         incr *= 180000.0;
-                     pos += incr;
-                     stream_seek(cur_stream, pos, incr, 1);
-                 } else {
-                     pos = get_master_clock(cur_stream);
-                     pos += incr;
-                     stream_seek(cur_stream, (int64_t)(pos * AV_TIME_BASE), (int64_t)(incr * AV_TIME_BASE), 0);
-                 }
 -                if (cur_stream) {
+                     if (seek_by_bytes) {
+                         if (cur_stream->video_stream >= 0 && cur_stream->video_current_pos >= 0) {
+                             pos = cur_stream->video_current_pos;
+                         } else if (cur_stream->audio_stream >= 0 && cur_stream->audio_pkt.pos >= 0) {
+                             pos = cur_stream->audio_pkt.pos;
+                         } else
+                             pos = avio_tell(cur_stream->ic->pb);
+                         if (cur_stream->ic->bit_rate)
+                             incr *= cur_stream->ic->bit_rate / 8.0;
+                         else
+                             incr *= 180000.0;
+                         pos += incr;
+                         stream_seek(cur_stream, pos, incr, 1);
+                     } else {
+                         pos = get_master_clock(cur_stream);
+                         pos += incr;
+                         stream_seek(cur_stream, (int64_t)(pos * AV_TIME_BASE), (int64_t)(incr * AV_TIME_BASE), 0);
+                     }
 -                }
                  break;
              default:
                  break;
                  break;
              }
          case SDL_MOUSEMOTION:
-             if(event.type ==SDL_MOUSEBUTTONDOWN){
-                 x= event.button.x;
-             }else{
-                 if(event.motion.state != SDL_PRESSED)
+             if (event.type == SDL_MOUSEBUTTONDOWN) {
+                 x = event.button.x;
+             } else {
+                 if (event.motion.state != SDL_PRESSED)
                      break;
-                 x= event.motion.x;
-             }
-             if(seek_by_bytes || cur_stream->ic->duration<=0){
-                 uint64_t size=  avio_size(cur_stream->ic->pb);
-                 stream_seek(cur_stream, size*x/cur_stream->width, 0, 1);
-             }else{
-                 int64_t ts;
-                 int ns, hh, mm, ss;
-                 int tns, thh, tmm, tss;
-                 tns = cur_stream->ic->duration/1000000LL;
-                 thh = tns/3600;
-                 tmm = (tns%3600)/60;
-                 tss = (tns%60);
-                 frac = x/cur_stream->width;
-                 ns = frac*tns;
-                 hh = ns/3600;
-                 mm = (ns%3600)/60;
-                 ss = (ns%60);
-                 fprintf(stderr, "Seek to %2.0f%% (%2d:%02d:%02d) of total duration (%2d:%02d:%02d)       \n", frac*100,
-                         hh, mm, ss, thh, tmm, tss);
-                 ts = frac*cur_stream->ic->duration;
-                 if (cur_stream->ic->start_time != AV_NOPTS_VALUE)
-                     ts += cur_stream->ic->start_time;
-                 stream_seek(cur_stream, ts, 0, 0);
+                 x = event.motion.x;
              }
 -            if (cur_stream) {
+                 if (seek_by_bytes || cur_stream->ic->duration <= 0) {
+                     uint64_t size =  avio_size(cur_stream->ic->pb);
+                     stream_seek(cur_stream, size*x/cur_stream->width, 0, 1);
+                 } else {
+                     int64_t ts;
+                     int ns, hh, mm, ss;
+                     int tns, thh, tmm, tss;
+                     tns  = cur_stream->ic->duration / 1000000LL;
+                     thh  = tns / 3600;
+                     tmm  = (tns % 3600) / 60;
+                     tss  = (tns % 60);
+                     frac = x / cur_stream->width;
+                     ns   = frac * tns;
+                     hh   = ns / 3600;
+                     mm   = (ns % 3600) / 60;
+                     ss   = (ns % 60);
+                     fprintf(stderr, "Seek to %2.0f%% (%2d:%02d:%02d) of total duration (%2d:%02d:%02d)       \n", frac*100,
+                             hh, mm, ss, thh, tmm, tss);
+                     ts = frac * cur_stream->ic->duration;
+                     if (cur_stream->ic->start_time != AV_NOPTS_VALUE)
+                         ts += cur_stream->ic->start_time;
+                     stream_seek(cur_stream, ts, 0, 0);
+                 }
 -            }
              break;
          case SDL_VIDEORESIZE:
-             screen = SDL_SetVideoMode(event.resize.w, event.resize.h, 0,
-                                       SDL_HWSURFACE|SDL_RESIZABLE|SDL_ASYNCBLIT|SDL_HWACCEL);
-             screen_width = cur_stream->width = event.resize.w;
-             screen_height= cur_stream->height= event.resize.h;
 -            if (cur_stream) {
+                 screen = SDL_SetVideoMode(event.resize.w, event.resize.h, 0,
+                                           SDL_HWSURFACE|SDL_RESIZABLE|SDL_ASYNCBLIT|SDL_HWACCEL);
+                 screen_width  = cur_stream->width  = event.resize.w;
+                 screen_height = cur_stream->height = event.resize.h;
 -            }
              break;
          case SDL_QUIT:
          case FF_QUIT_EVENT:
              alloc_picture(event.user.data1);
              break;
          case FF_REFRESH_EVENT:
 -            video_refresh_timer(event.user.data1);
 +            video_refresh(event.user.data1);
-             cur_stream->refresh=0;
+             cur_stream->refresh = 0;
              break;
          default:
              break;
@@@ -3041,52 -2962,51 +3041,52 @@@ static int opt_codec(void *o, const cha
      return 0;
  }
  
 +static int dummy;
 +
  static const OptionDef options[] = {
  #include "cmdutils_common_opts.h"
-     { "x", HAS_ARG, {(void*)opt_width}, "force displayed width", "width" },
-     { "y", HAS_ARG, {(void*)opt_height}, "force displayed height", "height" },
-     { "s", HAS_ARG | OPT_VIDEO, {(void*)opt_frame_size}, "set frame size (WxH or abbreviation)", "size" },
-     { "fs", OPT_BOOL, {(void*)&is_full_screen}, "force full screen" },
-     { "an", OPT_BOOL, {(void*)&audio_disable}, "disable audio" },
-     { "vn", OPT_BOOL, {(void*)&video_disable}, "disable video" },
-     { "ast", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&wanted_stream[AVMEDIA_TYPE_AUDIO]}, "select desired audio stream", "stream_number" },
-     { "vst", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&wanted_stream[AVMEDIA_TYPE_VIDEO]}, "select desired video stream", "stream_number" },
-     { "sst", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&wanted_stream[AVMEDIA_TYPE_SUBTITLE]}, "select desired subtitle stream", "stream_number" },
-     { "ss", HAS_ARG, {(void*)&opt_seek}, "seek to a given position in seconds", "pos" },
-     { "t", HAS_ARG, {(void*)&opt_duration}, "play  \"duration\" seconds of audio/video", "duration" },
-     { "bytes", OPT_INT | HAS_ARG, {(void*)&seek_by_bytes}, "seek by bytes 0=off 1=on -1=auto", "val" },
-     { "nodisp", OPT_BOOL, {(void*)&display_disable}, "disable graphical display" },
-     { "f", HAS_ARG, {(void*)opt_format}, "force format", "fmt" },
-     { "pix_fmt", HAS_ARG | OPT_EXPERT | OPT_VIDEO, {(void*)opt_frame_pix_fmt}, "set pixel format", "format" },
-     { "stats", OPT_BOOL | OPT_EXPERT, {(void*)&show_status}, "show status", "" },
-     { "bug", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&workaround_bugs}, "workaround bugs", "" },
-     { "fast", OPT_BOOL | OPT_EXPERT, {(void*)&fast}, "non spec compliant optimizations", "" },
-     { "genpts", OPT_BOOL | OPT_EXPERT, {(void*)&genpts}, "generate pts", "" },
-     { "drp", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&decoder_reorder_pts}, "let decoder reorder pts 0=off 1=on -1=auto", ""},
-     { "lowres", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&lowres}, "", "" },
-     { "skiploop", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&skip_loop_filter}, "", "" },
-     { "skipframe", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&skip_frame}, "", "" },
-     { "skipidct", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&skip_idct}, "", "" },
-     { "idct", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&idct}, "set idct algo",  "algo" },
-     { "er", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&error_recognition}, "set error detection threshold (0-4)",  "threshold" },
-     { "ec", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&error_concealment}, "set error concealment options",  "bit_mask" },
-     { "sync", HAS_ARG | OPT_EXPERT, {(void*)opt_sync}, "set audio-video sync. type (type=audio/video/ext)", "type" },
-     { "autoexit", OPT_BOOL | OPT_EXPERT, {(void*)&autoexit}, "exit at the end", "" },
-     { "exitonkeydown", OPT_BOOL | OPT_EXPERT, {(void*)&exit_on_keydown}, "exit on key down", "" },
-     { "exitonmousedown", OPT_BOOL | OPT_EXPERT, {(void*)&exit_on_mousedown}, "exit on mouse down", "" },
-     { "loop", OPT_INT | HAS_ARG | OPT_EXPERT, {(void*)&loop}, "set number of times the playback shall be looped", "loop count" },
-     { "framedrop", OPT_BOOL | OPT_EXPERT, {(void*)&framedrop}, "drop frames when cpu is too slow", "" },
-     { "window_title", OPT_STRING | HAS_ARG, {(void*)&window_title}, "set window title", "window title" },
+     { "x", HAS_ARG, { (void*)opt_width }, "force displayed width", "width" },
+     { "y", HAS_ARG, { (void*)opt_height }, "force displayed height", "height" },
+     { "s", HAS_ARG | OPT_VIDEO, { (void*)opt_frame_size }, "set frame size (WxH or abbreviation)", "size" },
+     { "fs", OPT_BOOL, { (void*)&is_full_screen }, "force full screen" },
+     { "an", OPT_BOOL, { (void*)&audio_disable }, "disable audio" },
+     { "vn", OPT_BOOL, { (void*)&video_disable }, "disable video" },
+     { "ast", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&wanted_stream[AVMEDIA_TYPE_AUDIO] }, "select desired audio stream", "stream_number" },
+     { "vst", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&wanted_stream[AVMEDIA_TYPE_VIDEO] }, "select desired video stream", "stream_number" },
+     { "sst", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&wanted_stream[AVMEDIA_TYPE_SUBTITLE] }, "select desired subtitle stream", "stream_number" },
+     { "ss", HAS_ARG, { (void*)&opt_seek }, "seek to a given position in seconds", "pos" },
+     { "t", HAS_ARG, { (void*)&opt_duration }, "play  \"duration\" seconds of audio/video", "duration" },
+     { "bytes", OPT_INT | HAS_ARG, { (void*)&seek_by_bytes }, "seek by bytes 0=off 1=on -1=auto", "val" },
+     { "nodisp", OPT_BOOL, { (void*)&display_disable }, "disable graphical display" },
+     { "f", HAS_ARG, { (void*)opt_format }, "force format", "fmt" },
+     { "pix_fmt", HAS_ARG | OPT_EXPERT | OPT_VIDEO, { (void*)opt_frame_pix_fmt }, "set pixel format", "format" },
+     { "stats", OPT_BOOL | OPT_EXPERT, { (void*)&show_status }, "show status", "" },
 -    { "debug", HAS_ARG | OPT_EXPERT, { (void*)opt_debug }, "print specific debug info", "" },
+     { "bug", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&workaround_bugs }, "workaround bugs", "" },
 -    { "vismv", HAS_ARG | OPT_EXPERT, { (void*)opt_vismv }, "visualize motion vectors", "" },
+     { "fast", OPT_BOOL | OPT_EXPERT, { (void*)&fast }, "non spec compliant optimizations", "" },
+     { "genpts", OPT_BOOL | OPT_EXPERT, { (void*)&genpts }, "generate pts", "" },
+     { "drp", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&decoder_reorder_pts }, "let decoder reorder pts 0=off 1=on -1=auto", ""},
+     { "lowres", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&lowres }, "", "" },
+     { "skiploop", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&skip_loop_filter }, "", "" },
+     { "skipframe", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&skip_frame }, "", "" },
+     { "skipidct", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&skip_idct }, "", "" },
+     { "idct", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&idct }, "set idct algo",  "algo" },
+     { "er", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&error_recognition }, "set error detection threshold (0-4)",  "threshold" },
+     { "ec", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&error_concealment }, "set error concealment options",  "bit_mask" },
+     { "sync", HAS_ARG | OPT_EXPERT, { (void*)opt_sync }, "set audio-video sync. type (type=audio/video/ext)", "type" },
 -    { "threads", HAS_ARG | OPT_EXPERT, { (void*)opt_thread_count }, "thread count", "count" },
+     { "autoexit", OPT_BOOL | OPT_EXPERT, { (void*)&autoexit }, "exit at the end", "" },
+     { "exitonkeydown", OPT_BOOL | OPT_EXPERT, { (void*)&exit_on_keydown }, "exit on key down", "" },
+     { "exitonmousedown", OPT_BOOL | OPT_EXPERT, { (void*)&exit_on_mousedown }, "exit on mouse down", "" },
+     { "loop", OPT_INT | HAS_ARG | OPT_EXPERT, { (void*)&loop }, "set number of times the playback shall be looped", "loop count" },
+     { "framedrop", OPT_BOOL | OPT_EXPERT, { (void*)&framedrop }, "drop frames when cpu is too slow", "" },
+     { "window_title", OPT_STRING | HAS_ARG, { (void*)&window_title }, "set window title", "window title" },
  #if CONFIG_AVFILTER
-     { "vf", OPT_STRING | HAS_ARG, {(void*)&vfilters}, "video filters", "filter list" },
+     { "vf", OPT_STRING | HAS_ARG, { (void*)&vfilters }, "video filters", "filter list" },
  #endif
-     { "rdftspeed", OPT_INT | HAS_ARG| OPT_AUDIO | OPT_EXPERT, {(void*)&rdftspeed}, "rdft speed", "msecs" },
+     { "rdftspeed", OPT_INT | HAS_ARG| OPT_AUDIO | OPT_EXPERT, { (void*)&rdftspeed }, "rdft speed", "msecs" },
 +    { "showmode", HAS_ARG, {(void*)opt_show_mode}, "select show mode (0 = video, 1 = waves, 2 = RDFT)", "mode" },
-     { "default", HAS_ARG | OPT_AUDIO | OPT_VIDEO | OPT_EXPERT, {(void*)opt_default}, "generic catch all option", "" },
+     { "default", HAS_ARG | OPT_AUDIO | OPT_VIDEO | OPT_EXPERT, { (void*)opt_default }, "generic catch all option", "" },
 -    { "i", 0, { NULL }, "avconv compatibility dummy option", ""},
 +    { "i", OPT_BOOL, {(void *)&dummy}, "read specified file", "input_file"},
 +    { "codec", HAS_ARG | OPT_FUNC2, {(void*)opt_codec}, "force decoder", "decoder" },
      { NULL, },
  };
  
@@@ -3207,21 -3114,12 +3207,21 @@@ int main(int argc, char **argv
      SDL_EventState(SDL_SYSWMEVENT, SDL_IGNORE);
      SDL_EventState(SDL_USEREVENT, SDL_IGNORE);
  
 +    if (av_lockmgr_register(lockmgr)) {
 +        fprintf(stderr, "Could not initialize lock manager!\n");
 +        do_exit(NULL);
 +    }
 +
      av_init_packet(&flush_pkt);
-     flush_pkt.data= "FLUSH";
+     flush_pkt.data = "FLUSH";
  
 -    cur_stream = stream_open(input_filename, file_iformat);
 +    is = stream_open(input_filename, file_iformat);
 +    if (!is) {
 +        fprintf(stderr, "Failed to initialize VideoState!\n");
 +        do_exit(NULL);
 +    }
  
 -    event_loop();
 +    event_loop(is);
  
      /* never returns */
  
index 690ea385ee97db89cc1f4eae96e851ef191fa3b4,b139a8a9ea9481b6ce4933b473b41acbaeb96812..b366674c7c15603ef0b128ed5dd7a864b662ead8
@@@ -795,10 -777,10 +795,14 @@@ typedef struct RcOverride
   * Codec supports changed parameters at any point.
   */
  #define CODEC_CAP_PARAM_CHANGE     0x4000
+ /**
+  * Codec supports avctx->thread_count == 0 (auto).
+  */
+ #define CODEC_CAP_AUTO_THREADS     0x8000
 +/**
 + * Codec is lossless.
 + */
 +#define CODEC_CAP_LOSSLESS         0x80000000
  
  //The following defines may change, don't expect compatibility if you use them.
  #define MB_TYPE_INTRA4x4   0x0001
index 25863cb7d512af2a52073c365dfa6d3e0c6ef93d,cfe7bdc738bde2204db3a445625778be02dd896e..2aa1a4cb658835e1cf0e3dcef2eca4d5270b7df4
@@@ -34,10 -34,9 +34,10 @@@ typedef struct BFIContext 
      AVCodecContext *avctx;
      AVFrame frame;
      uint8_t *dst;
 +    uint32_t pal[256];
  } BFIContext;
  
- static av_cold int bfi_decode_init(AVCodecContext * avctx)
+ static av_cold int bfi_decode_init(AVCodecContext *avctx)
  {
      BFIContext *bfi = avctx->priv_data;
      avctx->pix_fmt = PIX_FMT_PAL8;
@@@ -77,10 -75,10 +77,10 @@@ static int bfi_decode_frame(AVCodecCont
              av_log(NULL, AV_LOG_ERROR, "Palette is too large.\n");
              return -1;
          }
-         pal = (uint32_t *) bfi->frame.data[1];
+         pal = (uint32_t *)bfi->frame.data[1];
          for (i = 0; i < avctx->extradata_size / 3; i++) {
              int shift = 16;
 -            *pal = 0;
 +            *pal = 0xFF << 24;
              for (j = 0; j < 3; j++, shift -= 8)
                  *pal +=
                      ((avctx->extradata[i * 3 + j] << 2) |
      } else {
          bfi->frame.pict_type = AV_PICTURE_TYPE_P;
          bfi->frame.key_frame = 0;
 +        bfi->frame.palette_has_changed = 0;
 +        memcpy(bfi->frame.data[1], bfi->pal, sizeof(bfi->pal));
      }
  
-     buf += 4; //Unpacked size, not required.
+     buf += 4; // Unpacked size, not required.
  
      while (dst != frame_end) {
-         static const uint8_t lentab[4]={0,2,0,1};
-         unsigned int byte = *buf++, av_uninit(offset);
-         unsigned int code = byte >> 6;
+         static const uint8_t lentab[4] = { 0, 2, 0, 1 };
+         unsigned int byte   = *buf++, av_uninit(offset);
+         unsigned int code   = byte >> 6;
          unsigned int length = byte & ~0xC0;
  
          if (buf >= buf_end) {
Simple merge
Simple merge
index cdf3a391ccff707c8ea2e70115735d8630c8af85,58c5fcd638c7e574f18a540752fe630b384d9383..717b865bae2a044514268762b239588636a0a326
@@@ -189,11 -186,7 +189,11 @@@ static int get_logical_cpus(AVCodecCont
      nb_cpus = sysconf(_SC_NPROCESSORS_ONLN);
  #endif
      av_log(avctx, AV_LOG_DEBUG, "detected %d logical cores\n", nb_cpus);
-     return FFMIN(nb_cpus, MAX_AUTO_THREADS);
 +
 +    if  (avctx->height)
 +        nb_cpus = FFMIN(nb_cpus, (avctx->height+15)/16);
 +
+     return nb_cpus;
  }
  
  
@@@ -781,11 -769,11 +783,13 @@@ static int frame_thread_init(AVCodecCon
  
      if (!thread_count) {
          int nb_cpus = get_logical_cpus(avctx);
-         // use number of cores + 1 as thread count if there is motre than one
 +        if ((avctx->debug & (FF_DEBUG_VIS_QP | FF_DEBUG_VIS_MB_TYPE)) || avctx->debug_mv)
 +            nb_cpus = 1;
+         // use number of cores + 1 as thread count if there is more than one
          if (nb_cpus > 1)
-             thread_count = avctx->thread_count = nb_cpus + 1;
+             thread_count = avctx->thread_count = FFMIN(nb_cpus + 1, MAX_AUTO_THREADS);
+         else
+             thread_count = avctx->thread_count = 1;
      }
  
      if (thread_count <= 1) {
index d152ec2ae3d2ea3f951d442854d9d15337441269,c845a310cd0caeaad5cc6cd50955b20667313d52..619b70f3fba5b902ce732c054bc53ceff0964b39
@@@ -765,8 -710,10 +765,10 @@@ int attribute_align_arg avcodec_open2(A
              goto free_and_end;
          }
      }
+     if (!HAVE_THREADS && !(codec->capabilities & CODEC_CAP_AUTO_THREADS))
+         avctx->thread_count = 1;
  
 -    if (avctx->codec->max_lowres < avctx->lowres) {
 +    if (avctx->codec->max_lowres < avctx->lowres || avctx->lowres < 0) {
          av_log(avctx, AV_LOG_ERROR, "The maximum value for lowres supported by the decoder is %d\n",
                 avctx->codec->max_lowres);
          ret = AVERROR(EINVAL);
index 1a6e3300ef43765d0cf8bd9a591e8a1cfecd21b1,1317ef0ddcda922be21efcf90293a870cbe54e93..932bacdbb94ba021b02f3f34458859857f01ca1e
@@@ -21,8 -21,8 +21,8 @@@
  #define AVCODEC_VERSION_H
  
  #define LIBAVCODEC_VERSION_MAJOR 53
 -#define LIBAVCODEC_VERSION_MINOR 32
 -#define LIBAVCODEC_VERSION_MICRO  2
 +#define LIBAVCODEC_VERSION_MINOR 49
- #define LIBAVCODEC_VERSION_MICRO 101
++#define LIBAVCODEC_VERSION_MICRO 102
  
  #define LIBAVCODEC_VERSION_INT  AV_VERSION_INT(LIBAVCODEC_VERSION_MAJOR, \
                                                 LIBAVCODEC_VERSION_MINOR, \
index 8b1bbba0e18eea0f495b6187f3c8a195392679fa,43c973706d775d5a5c3bb6288c06fcf4040b3159..31a0115b8630b136dd68750a053610ee93a4742c
@@@ -1,25 -1,25 +1,25 @@@
- 0, 0, 308224, 0x7264439e
- 0, 11520, 308224, 0xe1734f4b
- 0, 23040, 308224, 0x9cfe28a4
- 0, 34560, 308224, 0xebb6ec8b
- 0, 46080, 308224, 0xaef16ca7
- 0, 57600, 308224, 0x0390b439
- 0, 69120, 308224, 0xe69bd008
- 0, 80640, 308224, 0xa1818468
- 0, 92160, 308224, 0x9d6e7d82
- 0, 103680, 308224, 0x54971a9e
- 0, 115200, 308224, 0xe14e15a8
- 0, 126720, 308224, 0xa026cf3f
- 0, 138240, 308224, 0xf8921be4
- 0, 149760, 308224, 0xf49a42cc
- 0, 161280, 308224, 0xa4108f17
- 0, 172800, 308224, 0xfa79cbfe
- 0, 184320, 308224, 0x3431f47b
- 0, 195840, 308224, 0x72aa3426
- 0, 207360, 308224, 0x81159f85
- 0, 218880, 308224, 0x04bcb289
- 0, 230400, 308224, 0xb1dabbcd
- 0, 241920, 308224, 0x7e851c8c
- 0, 253440, 308224, 0x8bdea0bf
- 0, 264960, 308224, 0xecacdb11
- 0, 276480, 308224, 0xec4c6c41
 -0, 0, 921600, 0x2e2b3ca4
 -0, 11520, 921600, 0x0ff7a368
 -0, 23040, 921600, 0xf5f0dc50
 -0, 34560, 921600, 0x56cb0c9d
 -0, 46080, 921600, 0xb253228f
 -0, 57600, 921600, 0xefd3419e
 -0, 69120, 921600, 0x708c0ce7
 -0, 80640, 921600, 0x0b3a7f6d
 -0, 92160, 921600, 0x72db4eac
 -0, 103680, 921600, 0x94328111
 -0, 115200, 921600, 0x95f7b2f0
 -0, 126720, 921600, 0xdc3c9655
 -0, 138240, 921600, 0xfe03dec6
 -0, 149760, 921600, 0x2551dffb
 -0, 161280, 921600, 0xe8b37d9e
 -0, 172800, 921600, 0xad93508b
 -0, 184320, 921600, 0x5a1c4890
 -0, 195840, 921600, 0x6f972fb4
 -0, 207360, 921600, 0xa1d5ff95
 -0, 218880, 921600, 0x7bc5d07c
 -0, 230400, 921600, 0xc0311e4e
 -0, 241920, 921600, 0x5b02cc48
 -0, 253440, 921600, 0x8db4d5fa
 -0, 264960, 921600, 0x31aae769
 -0, 276480, 921600, 0xab62b9a7
++0, 0, 921600, 0xb69faa34
++0, 11520, 921600, 0x38680829
++0, 23040, 921600, 0xa7263c5a
++0, 34560, 921600, 0xa784626a
++0, 46080, 921600, 0xb4c47212
++0, 57600, 921600, 0xd17285ea
++0, 69120, 921600, 0xe9b33902
++0, 80640, 921600, 0x215ea693
++0, 92160, 921600, 0xe2ab6c7a
++0, 103680, 921600, 0xf2867624
++0, 115200, 921600, 0x607d78c1
++0, 126720, 921600, 0x6e743bb7
++0, 138240, 921600, 0x1fbf8f5a
++0, 149760, 921600, 0xac6c912e
++0, 161280, 921600, 0x556933bc
++0, 172800, 921600, 0xda4c242b
++0, 184320, 921600, 0xa6b32f83
++0, 195840, 921600, 0x1ecc2996
++0, 207360, 921600, 0xf1c3fc0f
++0, 218880, 921600, 0x3f1db909
++0, 230400, 921600, 0x7582fb93
++0, 241920, 921600, 0x102ba261
++0, 253440, 921600, 0xfbcf9de0
++0, 264960, 921600, 0xe9ecb4d9
++0, 276480, 921600, 0x7ee36a42
index 72a32043b82937976a8a25cfbe05d3015a2fb1b6,720704aa01dabf3a58532aac535b4826b511d490..40da4e16b687df6fb6ed8ab52861b63c3f1e46e3
@@@ -1,8 -1,8 +1,8 @@@
- 0, 0, 65024, 0x8f31c3f0
- 0, 6390, 65024, 0x164a2d82
- 0, 12780, 65024, 0xbb72b738
- 0, 19170, 65024, 0x45b93e3a
- 0, 25560, 65024, 0xcc4019df
- 0, 31950, 65024, 0x64644557
- 0, 38340, 65024, 0xb4584b28
- 0, 44730, 65024, 0x1d87966a
 -0, 0, 192000, 0xbabcbd55
 -0, 6390, 192000, 0xf00a5683
 -0, 12780, 192000, 0xcce90589
 -0, 19170, 192000, 0x8545631f
 -0, 25560, 192000, 0xd3ab654c
 -0, 31950, 192000, 0x5e0dda12
 -0, 38340, 192000, 0x7e94b053
 -0, 44730, 192000, 0x8027e68b
++0, 0, 192000, 0x7384f9b2
++0, 6390, 192000, 0xd1f61c71
++0, 12780, 192000, 0x0c6937d1
++0, 19170, 192000, 0x56459a3a
++0, 25560, 192000, 0x6d011790
++0, 31950, 192000, 0xb5347ce8
++0, 38340, 192000, 0xcd422568
++0, 44730, 192000, 0xde4fef2d
index cda4cbc502c6c12ab659c11bef931b6c5438ef9b,f01fd13ac379eedd2b8d63946179993a99ae7493..53a3bed8df011eabc03a8547a134e0fbf151bb62
@@@ -1,9 -1,9 +1,9 @@@
- 0, 0, 65024, 0x10db5645
- 0, 6390, 65024, 0xb5d8a5bd
- 0, 12780, 65024, 0xc9555f27
- 0, 19170, 65024, 0x74c43f84
- 0, 25560, 65024, 0x5b2445b0
- 0, 31950, 65024, 0x8bd5be38
- 0, 38340, 65024, 0x75ec97da
- 0, 44730, 65024, 0x34416636
- 0, 51120, 65024, 0x9cc2abcf
 -0, 0, 192000, 0x8b8bd8de
 -0, 6390, 192000, 0xdac26ec2
 -0, 12780, 192000, 0x0fc01c28
 -0, 19170, 192000, 0x1251eef7
 -0, 25560, 192000, 0x89eced0e
 -0, 31950, 192000, 0x4943d821
 -0, 38340, 192000, 0x49258ec9
 -0, 44730, 192000, 0x9afd5881
 -0, 51120, 192000, 0xb322b901
++0, 0, 192000, 0x4269d703
++0, 6390, 192000, 0xdf8667e7
++0, 12780, 192000, 0x450026ad
++0, 19170, 192000, 0x2528ea52
++0, 25560, 192000, 0x83bcd1ec
++0, 31950, 192000, 0x88d5ba27
++0, 38340, 192000, 0x44424577
++0, 44730, 192000, 0xd93f12a3
++0, 51120, 192000, 0xcd625f3e
index 101fa2cc81783abe4c452c9a0776e0846cb93836,98af733117122ebc5286f63fd9dc3a3a03d464cd..2faad6e552205901ac4465103279961baea6d75b
@@@ -1,17 -1,17 +1,17 @@@
- 0, 0, 308224, 0x8dc9803f
- 0, 6390, 308224, 0x06308b37
- 0, 12780, 308224, 0xb8cb7be6
- 0, 19170, 308224, 0xc538862b
- 0, 25560, 308224, 0x8d4b7702
- 0, 31950, 308224, 0x97a479f0
- 0, 38340, 308224, 0x63d08e67
- 0, 44730, 308224, 0x470e8a18
- 0, 51120, 308224, 0x08aa6be4
- 0, 57510, 308224, 0x3b2f6f9a
- 0, 63900, 308224, 0xf0f1490c
- 0, 70290, 308224, 0xcb8b2ec5
- 0, 76680, 308224, 0xab361e75
- 0, 83070, 308224, 0x485aed6d
- 0, 89460, 308224, 0xd3e7ecb7
- 0, 95850, 308224, 0xa2c0d561
- 0, 102240, 308224, 0xd8f8ccd4
 -0, 0, 921600, 0x713f2da1
 -0, 6390, 921600, 0x9e772ec9
 -0, 12780, 921600, 0x9420310f
 -0, 19170, 921600, 0xd68f294f
 -0, 25560, 921600, 0xe25a1bcf
 -0, 31950, 921600, 0x32f903ec
 -0, 38340, 921600, 0xdb290b1c
 -0, 44730, 921600, 0x0b0d1b0f
 -0, 51120, 921600, 0x58430921
 -0, 57510, 921600, 0xe65dd39e
 -0, 63900, 921600, 0x146b3068
 -0, 70290, 921600, 0x6e1e7f78
 -0, 76680, 921600, 0x0166e01c
 -0, 83070, 921600, 0x83b86b56
 -0, 89460, 921600, 0xd52a1697
 -0, 95850, 921600, 0x5b38adc8
 -0, 102240, 921600, 0x457f6cea
++0, 0, 921600, 0x8a5d15df
++0, 6390, 921600, 0x92c01362
++0, 12780, 921600, 0xe1a31643
++0, 19170, 921600, 0x37a90fe2
++0, 25560, 921600, 0x74410783
++0, 31950, 921600, 0xecf4ef1a
++0, 38340, 921600, 0x4d7ff3d4
++0, 44730, 921600, 0xac820317
++0, 51120, 921600, 0xbe5ff56e
++0, 57510, 921600, 0x8e59c329
++0, 63900, 921600, 0x73bf23f3
++0, 70290, 921600, 0xb90c780f
++0, 76680, 921600, 0xfbd9dc32
++0, 83070, 921600, 0x30586821
++0, 89460, 921600, 0x6695195b
++0, 95850, 921600, 0xc449aa85
++0, 102240, 921600, 0xca6a391c
index f200ac5225912874339aa03bad67b5b8b14e68e5,0452f2b3114ac971b668d570eb5f2d632da6533e..68ba09e4eee109af8849c2d63a0d289c4825b48b
@@@ -1,10 -1,10 +1,10 @@@
- 0, 0, 65024, 0xbf9d558b
- 0, 9000, 65024, 0x4c7ea2ac
- 0, 18000, 65024, 0x4931827c
- 0, 27000, 65024, 0x5a9e09a7
- 0, 36000, 65024, 0x2b76eca9
- 0, 45000, 65024, 0xd5400a96
- 0, 54000, 65024, 0xcca17f23
- 0, 63000, 65024, 0xebca0dec
- 0, 72000, 65024, 0x07a73cfc
- 0, 81000, 65024, 0xdd5e4620
 -0, 0, 192000, 0x10380cf0
 -0, 9000, 192000, 0x1d74af4c
 -0, 18000, 192000, 0xd665492d
 -0, 27000, 192000, 0xbf544565
 -0, 36000, 192000, 0xf8a33b00
 -0, 45000, 192000, 0x7d08bbad
 -0, 54000, 192000, 0x10685a90
 -0, 63000, 192000, 0x0a1a9ef6
 -0, 72000, 192000, 0x3e967980
 -0, 81000, 192000, 0x9849f751
++0, 0, 192000, 0x236a1b54
++0, 9000, 192000, 0xfb438b68
++0, 18000, 192000, 0xde504563
++0, 27000, 192000, 0xfaf88e05
++0, 36000, 192000, 0xe15de5af
++0, 45000, 192000, 0x641fcca4
++0, 54000, 192000, 0x74899cb6
++0, 63000, 192000, 0x93fdb1b4
++0, 72000, 192000, 0x58d83456
++0, 81000, 192000, 0x7d3012ac
index 94760d0bc1d2a902d10274012d3562221bd7c74d,f19061b9667c1af43803e8ac5f3dad22f6e170e3..fbf00b658ce31b73cc26fbaeae8e87ed94b3bcb9
@@@ -1,13 -1,13 +1,13 @@@
- 0, 0, 308224, 0x5a24821c
- 0, 12780, 308224, 0xa1ecf793
- 0, 25560, 308224, 0xcb91afa5
- 0, 38340, 308224, 0x8b7e85b9
- 0, 51120, 308224, 0xe4755628
- 0, 63900, 308224, 0xe4755628
- 0, 76680, 308224, 0xe4755628
- 0, 89460, 308224, 0xe4755628
- 0, 102240, 308224, 0xe4755628
- 0, 115020, 308224, 0xe4755628
- 0, 127800, 308224, 0xdd6ca523
- 0, 140580, 308224, 0x961ba417
- 0, 153360, 308224, 0x5ed15e7f
 -0, 0, 921600, 0xe6309638
 -0, 12780, 921600, 0xa99a7665
 -0, 25560, 921600, 0x172ccfbb
 -0, 38340, 921600, 0xcf676571
 -0, 51120, 921600, 0x6a5077f2
 -0, 63900, 921600, 0x6a5077f2
 -0, 76680, 921600, 0x6a5077f2
 -0, 89460, 921600, 0x6a5077f2
 -0, 102240, 921600, 0x6a5077f2
 -0, 115020, 921600, 0x6a5077f2
 -0, 127800, 921600, 0xb83db404
 -0, 140580, 921600, 0x997ceb90
 -0, 153360, 921600, 0xd707157c
++0, 0, 921600, 0xd9e060e3
++0, 12780, 921600, 0x15e28dc7
++0, 25560, 921600, 0x78e8bfbc
++0, 38340, 921600, 0xe9407075
++0, 51120, 921600, 0xab818b8a
++0, 63900, 921600, 0xab818b8a
++0, 76680, 921600, 0xab818b8a
++0, 89460, 921600, 0xab818b8a
++0, 102240, 921600, 0xab818b8a
++0, 115020, 921600, 0xab818b8a
++0, 127800, 921600, 0xad5ad11c
++0, 140580, 921600, 0xe6e50f8c
++0, 153360, 921600, 0x9f127099
index 4aaacde6db8991a60ff5117347322840727b02f6,65aa1bc838bf1d41a14a5da3e7f8cd9ccd97b228..4b9a9926ee222527cae8f42c32f6caf339ff366e
@@@ -1,15 -1,15 +1,15 @@@
- 0, 0, 65024, 0x54831a1a
- 0, 9000, 65024, 0x110f5bad
- 0, 18000, 65024, 0xdd4f97fa
- 0, 27000, 65024, 0x1ab375b2
- 0, 36000, 65024, 0x311b51d3
- 0, 45000, 65024, 0xb0614f71
- 0, 54000, 65024, 0x6d968927
- 0, 63000, 65024, 0x28d85028
- 0, 72000, 65024, 0x74ea41f5
- 0, 81000, 65024, 0x3480b067
- 0, 90000, 65024, 0x3e1115d4
- 0, 99000, 65024, 0x0c715b57
- 0, 108000, 65024, 0x3acaaea3
- 0, 117000, 65024, 0x1b60f1e8
- 0, 126000, 65024, 0xcee14632
 -0, 0, 192000, 0xc0941c10
 -0, 9000, 192000, 0xe2fe3ae5
 -0, 18000, 192000, 0x4a352d98
 -0, 27000, 192000, 0x7b78e0bb
 -0, 36000, 192000, 0x855c6675
 -0, 45000, 192000, 0xf443dad6
 -0, 54000, 192000, 0xe7e2a2e1
 -0, 63000, 192000, 0xa9009c58
 -0, 72000, 192000, 0x551855ab
 -0, 81000, 192000, 0x253908c7
 -0, 90000, 192000, 0x616213c4
 -0, 99000, 192000, 0xa381c3b1
 -0, 108000, 192000, 0xa2d64152
 -0, 117000, 192000, 0x34ed0f72
 -0, 126000, 192000, 0x05be63b4
++0, 0, 192000, 0x9754890f
++0, 9000, 192000, 0x01668965
++0, 18000, 192000, 0xbd1b5e12
++0, 27000, 192000, 0x2e97fb9f
++0, 36000, 192000, 0xf8b452e2
++0, 45000, 192000, 0xc6859449
++0, 54000, 192000, 0x910844f7
++0, 63000, 192000, 0x99443581
++0, 72000, 192000, 0xec52d1e5
++0, 81000, 192000, 0x2fc66c35
++0, 90000, 192000, 0xd9af7379
++0, 99000, 192000, 0x947a26ef
++0, 108000, 192000, 0x7b77ab28
++0, 117000, 192000, 0x2507637e
++0, 126000, 192000, 0x6ce8c0ea
index 9adb6127753af38906a7db7d702b36836f47d797,92fe427eb519acbd5147d5bb6874288cf3d681f0..a59c7ff498a3f88a42ec10c43182ebf934baf7fb
@@@ -1,12 -1,12 +1,12 @@@
- 0, 0, 65024, 0x190f2398
- 0, 6390, 65024, 0x19d8c3e0
- 0, 12780, 65024, 0x848020a2
- 0, 19170, 65024, 0xbb64696f
- 0, 25560, 65024, 0x85886472
- 0, 31950, 65024, 0xc9c26668
- 0, 38340, 65024, 0xf24d1524
- 0, 44730, 65024, 0x64d98cd0
- 0, 51120, 65024, 0xa1323b5e
- 0, 57510, 65024, 0x9f48dcf9
- 0, 63900, 65024, 0x1a0591da
- 0, 70290, 65024, 0x8eabf12e
 -0, 0, 192000, 0x69f6a5f6
 -0, 6390, 192000, 0xc741d0a6
 -0, 12780, 192000, 0xba31e7a4
 -0, 19170, 192000, 0x7dc45080
 -0, 25560, 192000, 0x1c91dad5
 -0, 31950, 192000, 0x564b69b1
 -0, 38340, 192000, 0xdd9d9ae8
 -0, 44730, 192000, 0x605c05e1
 -0, 51120, 192000, 0xa5341ddb
 -0, 57510, 192000, 0x1ebff8ba
 -0, 63900, 192000, 0x240df237
 -0, 70290, 192000, 0xac641867
++0, 0, 192000, 0xb718dc63
++0, 6390, 192000, 0x2efb7b89
++0, 12780, 192000, 0x70827047
++0, 19170, 192000, 0x61e1fd2f
++0, 25560, 192000, 0x06f8bccd
++0, 31950, 192000, 0xf0362404
++0, 38340, 192000, 0xc00fc1b8
++0, 44730, 192000, 0x94265476
++0, 51120, 192000, 0x4b50ad23
++0, 57510, 192000, 0x4d578b60
++0, 63900, 192000, 0xfb14b875
++0, 70290, 192000, 0x81682338
index 33cc0fbee78de706b18ce5b43ba065dadaf3f213,c9612f0f5d4ad1c41ac8ff00aff61bbaef14188e..dce4264dd69331ad4ce8a2c1f58ce9fb3aeb7f34
@@@ -1,12 -1,12 +1,12 @@@
- 0, 0, 3648, 0xb6174031
- 0, 6390, 3648, 0x2e4649b0
- 0, 12780, 3648, 0xe05247cb
- 0, 19170, 3648, 0x003941f0
- 0, 25560, 3648, 0xa2563fed
- 0, 31950, 3648, 0x23d34cf1
- 0, 38340, 3648, 0x624f5173
- 0, 44730, 3648, 0xc07a491e
- 0, 51120, 3648, 0x74214090
- 0, 57510, 3648, 0xebfd469c
- 0, 63900, 3648, 0x60083f49
- 0, 70290, 3648, 0x6096486f
 -0, 0, 7866, 0xa0056fdb
 -0, 6390, 7866, 0xed906c7a
 -0, 12780, 7866, 0x1c6e6f7d
 -0, 19170, 7866, 0xa2c460f7
 -0, 25560, 7866, 0xcf2166d4
 -0, 31950, 7866, 0xea545432
 -0, 38340, 7866, 0x604a5a9e
 -0, 44730, 7866, 0xbbc95c89
 -0, 51120, 7866, 0x80b16b5b
 -0, 57510, 7866, 0x9a1660ae
 -0, 63900, 7866, 0x6f886b10
 -0, 70290, 7866, 0xad8b5c99
++0, 0, 7866, 0xab73dae7
++0, 6390, 7866, 0x100adec8
++0, 12780, 7866, 0x1a20ddfa
++0, 19170, 7866, 0xc358cd16
++0, 25560, 7866, 0xee0bd20e
++0, 31950, 7866, 0xef26bef9
++0, 38340, 7866, 0xa9d0c755
++0, 44730, 7866, 0x6c11cc7c
++0, 51120, 7866, 0x4d6ed988
++0, 57510, 7866, 0x9965cf24
++0, 63900, 7866, 0x9a12db24
++0, 70290, 7866, 0x2e85cfeb
index 0f695eec3d7cf0104cbcb4806871b35a728db76e,ade21de822f2aff87256c31ac2830a46d545bd52..c58a07633ee12b4d51e9c5bee8840d43dea9ae2c
@@@ -1,36 -1,36 +1,36 @@@
- 0, 0, 45932, 0xf9bc2e69
- 0, 6390, 45932, 0x5b8736ad
- 0, 12780, 45932, 0x4521ba17
- 0, 19170, 45932, 0xf3a374a9
- 0, 25560, 45932, 0x3fdfdc70
- 0, 31950, 45932, 0x4eb18dbb
- 0, 38340, 45932, 0x633c6377
- 0, 44730, 45932, 0x77dce8ba
- 0, 51120, 45932, 0x8246fecd
- 0, 57510, 45932, 0xe8864c0d
- 0, 63900, 45932, 0x995740d1
- 0, 70290, 45932, 0xc8a298ee
- 0, 76680, 45932, 0xa3535672
- 0, 83070, 45932, 0xb553f58b
- 0, 89460, 45932, 0x8a5b3b92
- 0, 95850, 45932, 0x1bcd50b0
- 0, 102240, 45932, 0xf22b0531
- 0, 108630, 45932, 0x5f62bc78
- 0, 115020, 45932, 0xc669075f
- 0, 121410, 45932, 0xae3b4e80
- 0, 127800, 45932, 0x3f52062f
- 0, 134190, 45932, 0xde97a978
- 0, 140580, 45932, 0x3ba7ca71
- 0, 146970, 45932, 0xe418aba1
- 0, 153360, 45932, 0xb8b3f24b
- 0, 159750, 45932, 0xd054791d
- 0, 166140, 45932, 0xddf121ce
- 0, 172530, 45932, 0xf0dcdd42
- 0, 178920, 45932, 0xd5aa9281
- 0, 185310, 45932, 0xffe8450b
- 0, 191700, 45932, 0x84f9424a
- 0, 198090, 45932, 0xe6c7592e
- 0, 204480, 45932, 0xc29c492d
- 0, 210870, 45932, 0x87186732
- 0, 217260, 45932, 0x02c73e12
- 0, 223650, 45932, 0x32eb90c8
 -0, 0, 134724, 0x2ab217de
 -0, 6390, 134724, 0xbf240f9a
 -0, 12780, 134724, 0x020a6010
 -0, 19170, 134724, 0x9a5f9374
 -0, 25560, 134724, 0x1e93a7e9
 -0, 31950, 134724, 0x9e4a4c55
 -0, 38340, 134724, 0x8f9d1bab
 -0, 44730, 134724, 0xb26ac45b
 -0, 51120, 134724, 0xc08706d2
 -0, 57510, 134724, 0x0806b031
 -0, 63900, 134724, 0x234dbb33
 -0, 70290, 134724, 0xe4cbfb2f
 -0, 76680, 134724, 0xf603f3fd
 -0, 83070, 134724, 0x205669d1
 -0, 89460, 134724, 0x7ddbb5e3
 -0, 95850, 134724, 0x8dfbb45a
 -0, 102240, 134724, 0x9632f681
 -0, 108630, 134724, 0x259e462c
 -0, 115020, 134724, 0x14f2bac1
 -0, 121410, 134724, 0xac3de7ed
 -0, 127800, 134724, 0x6b8af396
 -0, 134190, 134724, 0xd1e4bc1c
 -0, 140580, 134724, 0x716d1c73
 -0, 146970, 134724, 0x610956c8
 -0, 153360, 134724, 0x89ff8e86
 -0, 159750, 134724, 0xc3ea6b6f
 -0, 166140, 134724, 0x886688ef
 -0, 172530, 134724, 0xe60fc8c1
 -0, 178920, 134724, 0x22bd3131
 -0, 185310, 134724, 0xb1d74561
 -0, 191700, 134724, 0x61b069bc
 -0, 198090, 134724, 0x50b665c1
 -0, 204480, 134724, 0x027e5144
 -0, 210870, 134724, 0xfe0c31b4
 -0, 217260, 134724, 0x1e7a1f2d
 -0, 223650, 134724, 0x48bff03d
++0, 0, 134724, 0x53784ca9
++0, 6390, 134724, 0x14c345b7
++0, 12780, 134724, 0xe0d0dd51
++0, 19170, 134724, 0xd53b5610
++0, 25560, 134724, 0x7cbb8d47
++0, 31950, 134724, 0x875d67c4
++0, 38340, 134724, 0x9811c085
++0, 44730, 134724, 0x25f6d228
++0, 51120, 134724, 0x349495a0
++0, 57510, 134724, 0xd0d75311
++0, 63900, 134724, 0xb49cdfbb
++0, 70290, 134724, 0x9fa69518
++0, 76680, 134724, 0x28a1f58c
++0, 83070, 134724, 0xb8dab657
++0, 89460, 134724, 0x8c7e3b3b
++0, 95850, 134724, 0x37268acf
++0, 102240, 134724, 0xcce8ca02
++0, 108630, 134724, 0xe0fd0c28
++0, 115020, 134724, 0x5bdac906
++0, 121410, 134724, 0xdd850bf0
++0, 127800, 134724, 0x2002a228
++0, 134190, 134724, 0x633617ea
++0, 140580, 134724, 0x2a3ef337
++0, 146970, 134724, 0x507886c3
++0, 153360, 134724, 0x51c0f07b
++0, 159750, 134724, 0x5e73dce1
++0, 166140, 134724, 0x26acc6f0
++0, 172530, 134724, 0x360c4349
++0, 178920, 134724, 0xc7dbabd4
++0, 185310, 134724, 0x671bbf66
++0, 191700, 134724, 0x4d44df79
++0, 198090, 134724, 0x69eade5b
++0, 204480, 134724, 0x2b1bca82
++0, 210870, 134724, 0x8b16af47
++0, 217260, 134724, 0xb59fa1bd
++0, 223650, 134724, 0x2ec17c24
index d7a6a11a8c7aaa8cafd994d2c1ad5bceb1431428,b33152a982d84c90e9a10320e4bc2b852861cc81..82b763fb87164e85468669008a82edfa1a671ef8
@@@ -1,6 -1,6 +1,6 @@@
- 0, 0, 77076, 0x33b3bf99
- 0, 6390, 77076, 0xde70a282
- 0, 12780, 77076, 0x8d4c10a4
- 0, 19170, 77076, 0xeb536bcc
- 0, 25560, 77076, 0x86cce3e8
- 0, 31950, 77076, 0x292df285
 -0, 0, 228150, 0x188c6d9b
 -0, 6390, 228150, 0x658dbf2f
 -0, 12780, 228150, 0xc09a4b2e
 -0, 19170, 228150, 0x8777bc7d
 -0, 25560, 228150, 0xa388f0ce
 -0, 31950, 228150, 0x4e06666e
++0, 0, 228150, 0xde68df49
++0, 6390, 228150, 0x8e12bcaf
++0, 12780, 228150, 0x851b04f7
++0, 19170, 228150, 0x7e5e0950
++0, 25560, 228150, 0x1d92219f
++0, 31950, 228150, 0x93caa693