]> git.sesse.net Git - ffmpeg/blobdiff - libavformat/seek.c
bfin: hpeldsp: Split no_rnd pixel operations off into a separate file
[ffmpeg] / libavformat / seek.c
index 2f4595304da6b067de967987aea164ecd594329c..9be8db97845bc7617316f0da9c0b1014e83905fa 100644 (file)
 /*
- * Utility functions for seeking for use within FFmpeg format handlers.
+ * seek utility functions for use within format handlers
  *
  * Copyright (c) 2009 Ivan Schreter
  *
- * This file is part of FFmpeg.
+ * This file is part of Libav.
  *
- * FFmpeg is free software; you can redistribute it and/or
+ * Libav is free software; you can redistribute it and/or
  * modify it under the terms of the GNU Lesser General Public
  * License as published by the Free Software Foundation; either
  * version 2.1 of the License, or (at your option) any later version.
  *
- * FFmpeg is distributed in the hope that it will be useful,
+ * Libav is distributed in the hope that it will be useful,
  * but WITHOUT ANY WARRANTY; without even the implied warranty of
  * MERCHANTABILITY or FITNESS FOR A PARTICULAR PURPOSE.  See the GNU
  * Lesser General Public License for more details.
  *
  * You should have received a copy of the GNU Lesser General Public
- * License along with FFmpeg; if not, write to the Free Software
+ * License along with Libav; if not, write to the Free Software
  * Foundation, Inc., 51 Franklin Street, Fifth Floor, Boston, MA 02110-1301 USA
  */
 
+#include <stdint.h>
+
 #include "seek.h"
+#include "libavutil/mathematics.h"
 #include "libavutil/mem.h"
+#include "internal.h"
 
 // NOTE: implementation should be moved here in another patch, to keep patches
 // separated.
-extern void av_read_frame_flush(AVFormatContext *s);
-
-/**
- * Helper structure to store parser state of AVStream.
- */
-typedef struct AVStreamState {
-    // Saved members of AVStream
-    AVCodecParserContext   *parser;
-    AVPacket                cur_pkt;
-    int64_t                 last_IP_pts;
-    int64_t                 cur_dts;
-    int64_t                 reference_dts;
-    const uint8_t          *cur_ptr;
-    int                     cur_len;
-    int                     probe_packets;
-} AVStreamState;
-
-/**
- * Helper structure to store parser state of AVFormat.
- */
-struct AVParserState {
-    int64_t         fpos;                   ///< File position at the time of call.
-
-    // Saved members of AVFormatContext
-    AVStream       *cur_st;                 ///< Current stream.
-    AVPacketList   *packet_buffer;          ///< Packet buffer of original state.
-    AVPacketList   *raw_packet_buffer;      ///< Raw packet buffer of original state.
-    int raw_packet_buffer_remaining_size;   ///< Remaining size available for raw_packet_buffer.
-
-    // Saved info for streams.
-    int             nb_streams;             ///< Number of streams with stored state.
-    AVStreamState  *stream_states;          ///< States of individual streams (array).
-};
 
 /**
- * Helper structure describing keyframe search state of one stream.
+ * helper structure describing keyframe search state of one stream
  */
 typedef struct {
-    int64_t pos_lo;     ///< Position of the frame with low timestamp in file or INT64_MAX if not found (yet).
-    int64_t ts_lo;      ///< Frame presentation timestamp or same as pos_lo for byte seeking.
+    int64_t     pos_lo;      ///< position of the frame with low timestamp in file or INT64_MAX if not found (yet)
+    int64_t     ts_lo;       ///< frame presentation timestamp or same as pos_lo for byte seeking
 
-    int64_t pos_hi;     ///< Position of the frame with high timestamp in file or INT64_MAX if not found (yet).
-    int64_t ts_hi;      ///< Frame presentation timestamp or same as pos_hi for byte seeking.
+    int64_t     pos_hi;      ///< position of the frame with high timestamp in file or INT64_MAX if not found (yet)
+    int64_t     ts_hi;       ///< frame presentation timestamp or same as pos_hi for byte seeking
 
-    int64_t last_pos;   ///< Last known position of a frame, for multi-frame packets.
+    int64_t     last_pos;    ///< last known position of a frame, for multi-frame packets
 
-    int64_t     term_ts;    ///< Termination timestamp (which TS we already read).
-    AVRational  term_ts_tb; ///< Timebase for term_ts.
-    int64_t     first_ts;   ///< First packet timestamp in this iteration (to fill term_ts later).
-    AVRational  first_ts_tb;///< Timebase for first_ts.
+    int64_t     term_ts;     ///< termination timestamp (which TS we already read)
+    AVRational  term_ts_tb;  ///< timebase for term_ts
+    int64_t     first_ts;    ///< first packet timestamp in this iteration (to fill term_ts later)
+    AVRational  first_ts_tb; ///< timebase for first_ts
 
-    int         terminated; ///< Termination flag for current iteration.
+    int         terminated;  ///< termination flag for the current iteration
 } AVSyncPoint;
 
-/**
- * Compare two timestamps exactly, taking into account their respective time bases.
- *
- * @param ts_a timestamp A.
- * @param tb_a time base for timestamp A.
- * @param ts_b timestamp B.
- * @param tb_b time base for timestamp A.
- * @return -1. 0 or 1 if timestamp A is less than, equal or greater than timestamp B.
- */
-static int compare_ts(int64_t ts_a, AVRational tb_a, int64_t ts_b, AVRational tb_b)
-{
-    int64_t a, b, res;
-
-    if (ts_a == INT64_MIN)
-        return ts_a < ts_b ? -1 : 0;
-    if (ts_a == INT64_MAX)
-        return ts_a > ts_b ? 1 : 0;
-    if (ts_b == INT64_MIN)
-        return ts_a > ts_b ? 1 : 0;
-    if (ts_b == INT64_MAX)
-        return ts_a < ts_b ? -1 : 0;
-
-    a = ts_a * tb_a.num * tb_b.den;
-    b = ts_b * tb_b.num * tb_a.den;
-
-    res = a - b;
-    if (res == 0)
-        return 0;
-    else
-        return (res >> 63) | 1;
-}
-
 /**
  * Compute a distance between timestamps.
  *
  * Distances are only comparable, if same time bases are used for computing
  * distances.
  *
- * @param ts_hi high timestamp.
- * @param tb_hi high timestamp time base.
- * @param ts_lo low timestamp.
- * @param tb_lo low timestamp time base.
- * @return representation of distance between high and low timestamps.
+ * @param ts_hi high timestamp
+ * @param tb_hi high timestamp time base
+ * @param ts_lo low timestamp
+ * @param tb_lo low timestamp time base
+ * @return representation of distance between high and low timestamps
  */
-static int64_t ts_distance(int64_t ts_hi, AVRational tb_hi, int64_t ts_lo, AVRational tb_lo)
+static int64_t ts_distance(int64_t ts_hi,
+                           AVRational tb_hi,
+                           int64_t ts_lo,
+                           AVRational tb_lo)
 {
     int64_t hi, lo;
 
@@ -136,23 +78,23 @@ static int64_t ts_distance(int64_t ts_hi, AVRational tb_hi, int64_t ts_lo, AVRat
 /**
  * Partial search for keyframes in multiple streams.
  *
- * This routine searches for the next lower and next higher timestamp to
- * given target timestamp in each stream, starting at current file position
- * and ending at position, where all streams have already been examined
- * (or when all higher key frames found in first iteration).
+ * This routine searches in each stream for the next lower and the next higher
+ * timestamp compared to the given target timestamp. The search starts at the current
+ * file position and ends at the file position, where all streams have already been
+ * examined (or when all higher key frames are found in the first iteration).
  *
- * This routine is called iteratively with exponential backoff to find lower
+ * This routine is called iteratively with an exponential backoff to find the lower
  * timestamp.
  *
- * @param s                 format context.
- * @param timestamp         target timestamp (or position, if AVSEEK_FLAG_BYTE).
- * @param timebase          time base for timestamps.
- * @param flags             seeking flags.
- * @param sync              array with information per stream.
- * @param keyframes_to_find count of keyframes to find in total.
- * @param found_lo          pointer to count of already found low timestamp keyframes.
- * @param found_hi          pointer to count of already found high timestamp keyframes.
- * @param first_iter        flag for first iteration.
+ * @param s                 format context
+ * @param timestamp         target timestamp (or position, if AVSEEK_FLAG_BYTE)
+ * @param timebase          time base for timestamps
+ * @param flags             seeking flags
+ * @param sync              array with information per stream
+ * @param keyframes_to_find count of keyframes to find in total
+ * @param found_lo          ptr to the count of already found low timestamp keyframes
+ * @param found_hi          ptr to the count of already found high timestamp keyframes
+ * @param first_iter        flag for first iteration
  */
 static void search_hi_lo_keyframes(AVFormatContext *s,
                                    int64_t timestamp,
@@ -182,7 +124,7 @@ static void search_hi_lo_keyframes(AVFormatContext *s,
                 if (s->streams[idx]->discard < AVDISCARD_ALL) {
                     sp = &sync[idx];
                     if (sp->pos_hi == INT64_MAX) {
-                        // No high frame exists for this stream
+                        // no high frame exists for this stream
                         (*found_hi)++;
                         sp->ts_hi  = INT64_MAX;
                         sp->pos_hi = INT64_MAX - 1;
@@ -194,20 +136,20 @@ static void search_hi_lo_keyframes(AVFormatContext *s,
 
         idx = pkt.stream_index;
         st = s->streams[idx];
-        if (st->discard >= AVDISCARD_ALL) {
-            // This stream is not active, skip packet.
+        if (st->discard >= AVDISCARD_ALL)
+            // this stream is not active, skip packet
             continue;
-        }
+
         sp = &sync[idx];
 
         flg = pkt.flags;
         pos = pkt.pos;
         pts = pkt.pts;
         dts = pkt.dts;
-        if (pts == AV_NOPTS_VALUE) {
-            // Some formats don't provide PTS, only DTS.
+        if (pts == AV_NOPTS_VALUE)
+            // some formats don't provide PTS, only DTS
             pts = dts;
-        }
+
         av_free_packet(&pkt);
 
         // Multi-frame packets only return position for the very first frame.
@@ -216,21 +158,21 @@ static void search_hi_lo_keyframes(AVFormatContext *s,
         // position arrives. In this way, it's possible to seek to proper
         // position. Additionally, for parsers not providing position at all,
         // an approximation will be used (starting position of this iteration).
-        if (pos < 0) {
+        if (pos < 0)
             pos = sp->last_pos;
-        } else {
+        else
             sp->last_pos = pos;
-        }
 
         // Evaluate key frames with known TS (or any frames, if AVSEEK_FLAG_ANY set).
-        if (pts != AV_NOPTS_VALUE && ((flg & PKT_FLAG_KEY) || (flags & AVSEEK_FLAG_ANY))) {
+        if (pts != AV_NOPTS_VALUE &&
+            ((flg & AV_PKT_FLAG_KEY) || (flags & AVSEEK_FLAG_ANY))) {
             if (flags & AVSEEK_FLAG_BYTE) {
-                // For byte seeking, use position as timestamp.
+                // for byte seeking, use position as timestamp
                 ts        = pos;
                 ts_tb.num = 1;
                 ts_tb.den = 1;
             } else {
-                // Get stream time_base.
+                // otherwise, get stream time_base
                 ts    = pts;
                 ts_tb = st->time_base;
             }
@@ -244,13 +186,14 @@ static void search_hi_lo_keyframes(AVFormatContext *s,
                 sp->first_ts_tb = ts_tb;
             }
 
-            if (sp->term_ts != AV_NOPTS_VALUE && compare_ts(ts, ts_tb, sp->term_ts, sp->term_ts_tb) > 0) {
-                // We are past the end position from last iteration, ignore packet.
+            if (sp->term_ts != AV_NOPTS_VALUE &&
+                av_compare_ts(ts, ts_tb, sp->term_ts, sp->term_ts_tb) > 0) {
+                // past the end position from last iteration, ignore packet
                 if (!sp->terminated) {
                     sp->terminated = 1;
                     ++terminated_count;
                     if (sp->pos_hi == INT64_MAX) {
-                        // No high frame exists for this stream
+                        // no high frame exists for this stream
                         (*found_hi)++;
                         sp->ts_hi  = INT64_MAX;
                         sp->pos_hi = INT64_MAX - 1;
@@ -261,23 +204,23 @@ static void search_hi_lo_keyframes(AVFormatContext *s,
                 continue;
             }
 
-            if (compare_ts(ts, ts_tb, timestamp, timebase) <= 0) {
-                // Keyframe found before target timestamp.
+            if (av_compare_ts(ts, ts_tb, timestamp, timebase) <= 0) {
+                // keyframe found before target timestamp
                 if (sp->pos_lo == INT64_MAX) {
-                    // Found first keyframe lower than target timestamp.
+                    // found first keyframe lower than target timestamp
                     (*found_lo)++;
                     sp->ts_lo  = ts;
                     sp->pos_lo = pos;
                 } else if (sp->ts_lo < ts) {
-                    // Found a better match (closer to target timestamp).
+                    // found a better match (closer to target timestamp)
                     sp->ts_lo  = ts;
                     sp->pos_lo = pos;
                 }
             }
-            if (compare_ts(ts, ts_tb, timestamp, timebase) >= 0) {
-                // Keyframe found after target timestamp.
+            if (av_compare_ts(ts, ts_tb, timestamp, timebase) >= 0) {
+                // keyframe found after target timestamp
                 if (sp->pos_hi == INT64_MAX) {
-                    // Found first keyframe higher than target timestamp.
+                    // found first keyframe higher than target timestamp
                     (*found_hi)++;
                     sp->ts_hi  = ts;
                     sp->pos_hi = pos;
@@ -288,7 +231,7 @@ static void search_hi_lo_keyframes(AVFormatContext *s,
                         break;
                     }
                 } else if (sp->ts_hi > ts) {
-                    // Found a better match (actually, shouldn't happen).
+                    // found a better match (actually, shouldn't happen)
                     sp->ts_hi  = ts;
                     sp->pos_hi = pos;
                 }
@@ -297,7 +240,7 @@ static void search_hi_lo_keyframes(AVFormatContext *s,
     }
 
     // Clean up the parser.
-    av_read_frame_flush(s);
+    ff_read_frame_flush(s);
 }
 
 int64_t ff_gen_syncpoint_search(AVFormatContext *s,
@@ -321,27 +264,27 @@ int64_t ff_gen_syncpoint_search(AVFormatContext *s,
     AVRational time_base;
 
     if (flags & AVSEEK_FLAG_BYTE) {
-        /* For byte seeking, we have exact 1:1 "timestamps" - positions */
+        // for byte seeking, we have exact 1:1 "timestamps" - positions
         time_base.num = 1;
         time_base.den = 1;
     } else {
         if (stream_index >= 0) {
-            /* We have a reference stream, which time base we use */
+            // we have a reference stream, which time base we use
             st = s->streams[stream_index];
             time_base = st->time_base;
         } else {
-            /* No reference stream, use AV_TIME_BASE as reference time base */
+            // no reference stream, use AV_TIME_BASE as reference time base
             time_base.num = 1;
             time_base.den = AV_TIME_BASE;
         }
     }
 
     // Initialize syncpoint structures for each stream.
-    sync = (AVSyncPoint*) av_malloc(s->nb_streams * sizeof(AVSyncPoint));
-    if (!sync) {
+    sync = av_malloc(s->nb_streams * sizeof(AVSyncPoint));
+    if (!sync)
         // cannot allocate helper structure
         return -1;
-    }
+
     for (i = 0; i < s->nb_streams; ++i) {
         st = s->streams[i];
         sp = &sync[i];
@@ -362,18 +305,18 @@ int64_t ff_gen_syncpoint_search(AVFormatContext *s,
             ++keyframes_to_find;
     }
 
-    if (keyframes_to_find == 0) {
-        // No stream active, error.
+    if (!keyframes_to_find) {
+        // no stream active, error
         av_free(sync);
         return -1;
     }
 
     // Find keyframes in all active streams with timestamp/position just before
     // and just after requested timestamp/position.
-    step = 1024;
-    curpos = pos;
+    step = s->pb->buffer_size;
+    curpos = FFMAX(pos - step / 2, 0);
     for (;;) {
-        url_fseek(s->pb, curpos, SEEK_SET);
+        avio_seek(s->pb, curpos, SEEK_SET);
         search_hi_lo_keyframes(s,
                                ts, time_base,
                                flags,
@@ -383,7 +326,7 @@ int64_t ff_gen_syncpoint_search(AVFormatContext *s,
                                first_iter);
         if (found_lo == keyframes_to_find && found_hi == keyframes_to_find)
             break;  // have all keyframes we wanted
-        if (curpos == 0)
+        if (!curpos)
             break;  // cannot go back anymore
 
         curpos = pos - step;
@@ -419,15 +362,15 @@ int64_t ff_gen_syncpoint_search(AVFormatContext *s,
             min_distance = INT64_MAX;
             // Find timestamp closest to requested timestamp within min/max limits.
             if (sp->pos_lo != INT64_MAX
-                && compare_ts(ts_min, time_base, sp->ts_lo, st->time_base) <= 0
-                && compare_ts(sp->ts_lo, st->time_base, ts_max, time_base) <= 0) {
+                && av_compare_ts(ts_min, time_base, sp->ts_lo, st->time_base) <= 0
+                && av_compare_ts(sp->ts_lo, st->time_base, ts_max, time_base) <= 0) {
                 // low timestamp is in range
                 min_distance = ts_distance(ts, time_base, sp->ts_lo, st->time_base);
                 min_pos = sp->pos_lo;
             }
             if (sp->pos_hi != INT64_MAX
-                && compare_ts(ts_min, time_base, sp->ts_hi, st->time_base) <= 0
-                && compare_ts(sp->ts_hi, st->time_base, ts_max, time_base) <= 0) {
+                && av_compare_ts(ts_min, time_base, sp->ts_hi, st->time_base) <= 0
+                && av_compare_ts(sp->ts_hi, st->time_base, ts_max, time_base) <= 0) {
                 // high timestamp is in range, check distance
                 distance = ts_distance(sp->ts_hi, st->time_base, ts, time_base);
                 if (distance < min_distance) {
@@ -445,7 +388,7 @@ int64_t ff_gen_syncpoint_search(AVFormatContext *s,
         }
     }
 
-    url_fseek(s->pb, pos, SEEK_SET);
+    avio_seek(s->pb, pos, SEEK_SET);
     av_free(sync);
     return pos;
 }
@@ -454,27 +397,27 @@ AVParserState *ff_store_parser_state(AVFormatContext *s)
 {
     int i;
     AVStream *st;
-    AVStreamState *ss;
-    AVParserState *state = (AVParserState*) av_malloc(sizeof(AVParserState));
+    AVParserStreamState *ss;
+    AVParserState *state = av_malloc(sizeof(AVParserState));
     if (!state)
         return NULL;
 
-    state->stream_states = (AVStreamState*) av_malloc(sizeof(AVStreamState) * s->nb_streams);
+    state->stream_states = av_malloc(sizeof(AVParserStreamState) * s->nb_streams);
     if (!state->stream_states) {
         av_free(state);
         return NULL;
     }
 
-    state->fpos = url_ftell(s->pb);
+    state->fpos = avio_tell(s->pb);
 
     // copy context structures
-    state->cur_st                           = s->cur_st;
     state->packet_buffer                    = s->packet_buffer;
+    state->parse_queue                      = s->parse_queue;
     state->raw_packet_buffer                = s->raw_packet_buffer;
     state->raw_packet_buffer_remaining_size = s->raw_packet_buffer_remaining_size;
 
-    s->cur_st                               = NULL;
     s->packet_buffer                        = NULL;
+    s->parse_queue                          = NULL;
     s->raw_packet_buffer                    = NULL;
     s->raw_packet_buffer_remaining_size     = RAW_PACKET_BUFFER_SIZE;
 
@@ -487,20 +430,12 @@ AVParserState *ff_store_parser_state(AVFormatContext *s)
         ss->parser        = st->parser;
         ss->last_IP_pts   = st->last_IP_pts;
         ss->cur_dts       = st->cur_dts;
-        ss->reference_dts = st->reference_dts;
-        ss->cur_ptr       = st->cur_ptr;
-        ss->cur_len       = st->cur_len;
         ss->probe_packets = st->probe_packets;
-        ss->cur_pkt       = st->cur_pkt;
 
         st->parser        = NULL;
         st->last_IP_pts   = AV_NOPTS_VALUE;
         st->cur_dts       = AV_NOPTS_VALUE;
-        st->reference_dts = AV_NOPTS_VALUE;
-        st->cur_ptr       = NULL;
-        st->cur_len       = 0;
         st->probe_packets = MAX_PROBE_PACKETS;
-        av_init_packet(&st->cur_pkt);
     }
 
     return state;
@@ -510,17 +445,17 @@ void ff_restore_parser_state(AVFormatContext *s, AVParserState *state)
 {
     int i;
     AVStream *st;
-    AVStreamState *ss;
-    av_read_frame_flush(s);
+    AVParserStreamState *ss;
+    ff_read_frame_flush(s);
 
     if (!state)
         return;
 
-    url_fseek(s->pb, state->fpos, SEEK_SET);
+    avio_seek(s->pb, state->fpos, SEEK_SET);
 
     // copy context structures
-    s->cur_st                           = state->cur_st;
     s->packet_buffer                    = state->packet_buffer;
+    s->parse_queue                      = state->parse_queue;
     s->raw_packet_buffer                = state->raw_packet_buffer;
     s->raw_packet_buffer_remaining_size = state->raw_packet_buffer_remaining_size;
 
@@ -532,11 +467,7 @@ void ff_restore_parser_state(AVFormatContext *s, AVParserState *state)
         st->parser        = ss->parser;
         st->last_IP_pts   = ss->last_IP_pts;
         st->cur_dts       = ss->cur_dts;
-        st->reference_dts = ss->reference_dts;
-        st->cur_ptr       = ss->cur_ptr;
-        st->cur_len       = ss->cur_len;
         st->probe_packets = ss->probe_packets;
-        st->cur_pkt       = ss->cur_pkt;
     }
 
     av_free(state->stream_states);
@@ -557,7 +488,7 @@ static void free_packet_list(AVPacketList *pktl)
 void ff_free_parser_state(AVFormatContext *s, AVParserState *state)
 {
     int i;
-    AVStreamState *ss;
+    AVParserStreamState *ss;
 
     if (!state)
         return;
@@ -566,13 +497,12 @@ void ff_free_parser_state(AVFormatContext *s, AVParserState *state)
         ss = &state->stream_states[i];
         if (ss->parser)
             av_parser_close(ss->parser);
-        av_free_packet(&ss->cur_pkt);
     }
 
     free_packet_list(state->packet_buffer);
+    free_packet_list(state->parse_queue);
     free_packet_list(state->raw_packet_buffer);
 
     av_free(state->stream_states);
     av_free(state);
 }
-