Spaces:
Runtime error
Runtime error
/* | |
* This file is part of FFmpeg. | |
* | |
* FFmpeg 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, | |
* 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 | |
* Foundation, Inc., 51 Franklin Street, Fifth Floor, Boston, MA 02110-1301 USA | |
*/ | |
// deprecated features | |
enum VideoSyncMethod { | |
VSYNC_AUTO = -1, | |
VSYNC_PASSTHROUGH, | |
VSYNC_CFR, | |
VSYNC_VFR, | |
VSYNC_VSCFR, | |
VSYNC_DROP, | |
}; | |
enum HWAccelID { | |
HWACCEL_NONE = 0, | |
HWACCEL_AUTO, | |
HWACCEL_GENERIC, | |
}; | |
typedef struct HWDevice { | |
const char *name; | |
enum AVHWDeviceType type; | |
AVBufferRef *device_ref; | |
} HWDevice; | |
/* select an input stream for an output stream */ | |
typedef struct StreamMap { | |
int disabled; /* 1 is this mapping is disabled by a negative map */ | |
int file_index; | |
int stream_index; | |
char *linklabel; /* name of an output link, for mapping lavfi outputs */ | |
} StreamMap; | |
typedef struct { | |
int file_idx, stream_idx, channel_idx; // input | |
int ofile_idx, ostream_idx; // output | |
} AudioChannelMap; | |
typedef struct OptionsContext { | |
OptionGroup *g; | |
/* input/output options */ | |
int64_t start_time; | |
int64_t start_time_eof; | |
int seek_timestamp; | |
const char *format; | |
SpecifierOpt *codec_names; | |
int nb_codec_names; | |
SpecifierOpt *audio_ch_layouts; | |
int nb_audio_ch_layouts; | |
SpecifierOpt *audio_channels; | |
int nb_audio_channels; | |
SpecifierOpt *audio_sample_rate; | |
int nb_audio_sample_rate; | |
SpecifierOpt *frame_rates; | |
int nb_frame_rates; | |
SpecifierOpt *max_frame_rates; | |
int nb_max_frame_rates; | |
SpecifierOpt *frame_sizes; | |
int nb_frame_sizes; | |
SpecifierOpt *frame_pix_fmts; | |
int nb_frame_pix_fmts; | |
/* input options */ | |
int64_t input_ts_offset; | |
int loop; | |
int rate_emu; | |
float readrate; | |
int accurate_seek; | |
int thread_queue_size; | |
int input_sync_ref; | |
int find_stream_info; | |
SpecifierOpt *ts_scale; | |
int nb_ts_scale; | |
SpecifierOpt *dump_attachment; | |
int nb_dump_attachment; | |
SpecifierOpt *hwaccels; | |
int nb_hwaccels; | |
SpecifierOpt *hwaccel_devices; | |
int nb_hwaccel_devices; | |
SpecifierOpt *hwaccel_output_formats; | |
int nb_hwaccel_output_formats; | |
SpecifierOpt *autorotate; | |
int nb_autorotate; | |
/* output options */ | |
StreamMap *stream_maps; | |
int nb_stream_maps; | |
AudioChannelMap *audio_channel_maps; /* one info entry per -map_channel */ | |
int nb_audio_channel_maps; /* number of (valid) -map_channel settings */ | |
const char **attachments; | |
int nb_attachments; | |
int chapters_input_file; | |
int64_t recording_time; | |
int64_t stop_time; | |
int64_t limit_filesize; | |
float mux_preload; | |
float mux_max_delay; | |
float shortest_buf_duration; | |
int shortest; | |
int bitexact; | |
int video_disable; | |
int audio_disable; | |
int subtitle_disable; | |
int data_disable; | |
/* indexed by output file stream index */ | |
int *streamid_map; | |
int nb_streamid_map; | |
SpecifierOpt *metadata; | |
int nb_metadata; | |
SpecifierOpt *max_frames; | |
int nb_max_frames; | |
SpecifierOpt *bitstream_filters; | |
int nb_bitstream_filters; | |
SpecifierOpt *codec_tags; | |
int nb_codec_tags; | |
SpecifierOpt *sample_fmts; | |
int nb_sample_fmts; | |
SpecifierOpt *qscale; | |
int nb_qscale; | |
SpecifierOpt *forced_key_frames; | |
int nb_forced_key_frames; | |
SpecifierOpt *fps_mode; | |
int nb_fps_mode; | |
SpecifierOpt *force_fps; | |
int nb_force_fps; | |
SpecifierOpt *frame_aspect_ratios; | |
int nb_frame_aspect_ratios; | |
SpecifierOpt *display_rotations; | |
int nb_display_rotations; | |
SpecifierOpt *display_hflips; | |
int nb_display_hflips; | |
SpecifierOpt *display_vflips; | |
int nb_display_vflips; | |
SpecifierOpt *rc_overrides; | |
int nb_rc_overrides; | |
SpecifierOpt *intra_matrices; | |
int nb_intra_matrices; | |
SpecifierOpt *inter_matrices; | |
int nb_inter_matrices; | |
SpecifierOpt *chroma_intra_matrices; | |
int nb_chroma_intra_matrices; | |
SpecifierOpt *top_field_first; | |
int nb_top_field_first; | |
SpecifierOpt *metadata_map; | |
int nb_metadata_map; | |
SpecifierOpt *presets; | |
int nb_presets; | |
SpecifierOpt *copy_initial_nonkeyframes; | |
int nb_copy_initial_nonkeyframes; | |
SpecifierOpt *copy_prior_start; | |
int nb_copy_prior_start; | |
SpecifierOpt *filters; | |
int nb_filters; | |
SpecifierOpt *filter_scripts; | |
int nb_filter_scripts; | |
SpecifierOpt *reinit_filters; | |
int nb_reinit_filters; | |
SpecifierOpt *fix_sub_duration; | |
int nb_fix_sub_duration; | |
SpecifierOpt *fix_sub_duration_heartbeat; | |
int nb_fix_sub_duration_heartbeat; | |
SpecifierOpt *canvas_sizes; | |
int nb_canvas_sizes; | |
SpecifierOpt *pass; | |
int nb_pass; | |
SpecifierOpt *passlogfiles; | |
int nb_passlogfiles; | |
SpecifierOpt *max_muxing_queue_size; | |
int nb_max_muxing_queue_size; | |
SpecifierOpt *muxing_queue_data_threshold; | |
int nb_muxing_queue_data_threshold; | |
SpecifierOpt *guess_layout_max; | |
int nb_guess_layout_max; | |
SpecifierOpt *apad; | |
int nb_apad; | |
SpecifierOpt *discard; | |
int nb_discard; | |
SpecifierOpt *disposition; | |
int nb_disposition; | |
SpecifierOpt *program; | |
int nb_program; | |
SpecifierOpt *time_bases; | |
int nb_time_bases; | |
SpecifierOpt *enc_time_bases; | |
int nb_enc_time_bases; | |
SpecifierOpt *autoscale; | |
int nb_autoscale; | |
SpecifierOpt *bits_per_raw_sample; | |
int nb_bits_per_raw_sample; | |
SpecifierOpt *enc_stats_pre; | |
int nb_enc_stats_pre; | |
SpecifierOpt *enc_stats_post; | |
int nb_enc_stats_post; | |
SpecifierOpt *mux_stats; | |
int nb_mux_stats; | |
SpecifierOpt *enc_stats_pre_fmt; | |
int nb_enc_stats_pre_fmt; | |
SpecifierOpt *enc_stats_post_fmt; | |
int nb_enc_stats_post_fmt; | |
SpecifierOpt *mux_stats_fmt; | |
int nb_mux_stats_fmt; | |
} OptionsContext; | |
typedef struct InputFilter { | |
AVFilterContext *filter; | |
struct InputStream *ist; | |
struct FilterGraph *graph; | |
uint8_t *name; | |
enum AVMediaType type; // AVMEDIA_TYPE_SUBTITLE for sub2video | |
AVFifo *frame_queue; | |
// parameters configured for this input | |
int format; | |
int width, height; | |
AVRational sample_aspect_ratio; | |
int sample_rate; | |
AVChannelLayout ch_layout; | |
AVBufferRef *hw_frames_ctx; | |
int32_t *displaymatrix; | |
int eof; | |
} InputFilter; | |
typedef struct OutputFilter { | |
AVFilterContext *filter; | |
struct OutputStream *ost; | |
struct FilterGraph *graph; | |
uint8_t *name; | |
/* temporary storage until stream maps are processed */ | |
AVFilterInOut *out_tmp; | |
enum AVMediaType type; | |
/* desired output stream properties */ | |
int width, height; | |
AVRational frame_rate; | |
int format; | |
int sample_rate; | |
AVChannelLayout ch_layout; | |
// those are only set if no format is specified and the encoder gives us multiple options | |
// They point directly to the relevant lists of the encoder. | |
const int *formats; | |
const AVChannelLayout *ch_layouts; | |
const int *sample_rates; | |
} OutputFilter; | |
typedef struct FilterGraph { | |
int index; | |
const char *graph_desc; | |
AVFilterGraph *graph; | |
int reconfiguration; | |
// true when the filtergraph contains only meta filters | |
// that do not modify the frame data | |
int is_meta; | |
InputFilter **inputs; | |
int nb_inputs; | |
OutputFilter **outputs; | |
int nb_outputs; | |
} FilterGraph; | |
typedef struct InputStream { | |
int file_index; | |
AVStream *st; | |
int discard; /* true if stream data should be discarded */ | |
int user_set_discard; | |
int decoding_needed; /* non zero if the packets must be decoded in 'raw_fifo', see DECODING_FOR_* */ | |
int processing_needed; /* non zero if the packets must be processed */ | |
// should attach FrameData as opaque_ref after decoding | |
int want_frame_data; | |
/** | |
* Codec parameters - to be used by the decoding/streamcopy code. | |
* st->codecpar should not be accessed, because it may be modified | |
* concurrently by the demuxing thread. | |
*/ | |
AVCodecParameters *par; | |
AVCodecContext *dec_ctx; | |
const AVCodec *dec; | |
AVFrame *decoded_frame; | |
AVPacket *pkt; | |
AVRational framerate_guessed; | |
int64_t prev_pkt_pts; | |
int64_t start; /* time when read started */ | |
/* predicted dts of the next packet read for this stream or (when there are | |
* several frames in a packet) of the next frame in current packet (in AV_TIME_BASE units) */ | |
int64_t next_dts; | |
int64_t first_dts; ///< dts of the first packet read for this stream (in AV_TIME_BASE units) | |
int64_t dts; ///< dts of the last packet read for this stream (in AV_TIME_BASE units) | |
int64_t next_pts; ///< synthetic pts for the next decode frame (in AV_TIME_BASE units) | |
int64_t pts; ///< current pts of the decoded frame (in AV_TIME_BASE units) | |
int wrap_correction_done; | |
// the value of AVCodecParserContext.repeat_pict from the AVStream parser | |
// for the last packet returned from ifile_get_packet() | |
// -1 if unknown | |
// FIXME: this is a hack, the avstream parser should not be used | |
int last_pkt_repeat_pict; | |
int64_t filter_in_rescale_delta_last; | |
int64_t min_pts; /* pts with the smallest value in a current stream */ | |
int64_t max_pts; /* pts with the higher value in a current stream */ | |
// when forcing constant input framerate through -r, | |
// this contains the pts that will be given to the next decoded frame | |
int64_t cfr_next_pts; | |
int64_t nb_samples; /* number of samples in the last decoded audio frame before looping */ | |
double ts_scale; | |
int saw_first_ts; | |
AVDictionary *decoder_opts; | |
AVRational framerate; /* framerate forced with -r */ | |
int top_field_first; | |
int guess_layout_max; | |
int autorotate; | |
int fix_sub_duration; | |
struct { /* previous decoded subtitle and related variables */ | |
int got_output; | |
int ret; | |
AVSubtitle subtitle; | |
} prev_sub; | |
struct sub2video { | |
int64_t last_pts; | |
int64_t end_pts; | |
AVFifo *sub_queue; ///< queue of AVSubtitle* before filter init | |
AVFrame *frame; | |
int w, h; | |
unsigned int initialize; ///< marks if sub2video_update should force an initialization | |
} sub2video; | |
/* decoded data from this stream goes into all those filters | |
* currently video and audio only */ | |
InputFilter **filters; | |
int nb_filters; | |
int reinit_filters; | |
/* hwaccel options */ | |
enum HWAccelID hwaccel_id; | |
enum AVHWDeviceType hwaccel_device_type; | |
char *hwaccel_device; | |
enum AVPixelFormat hwaccel_output_format; | |
int (*hwaccel_retrieve_data)(AVCodecContext *s, AVFrame *frame); | |
enum AVPixelFormat hwaccel_pix_fmt; | |
/* stats */ | |
// combined size of all the packets read | |
uint64_t data_size; | |
/* number of packets successfully read for this stream */ | |
uint64_t nb_packets; | |
// number of frames/samples retrieved from the decoder | |
uint64_t frames_decoded; | |
uint64_t samples_decoded; | |
int64_t *dts_buffer; | |
int nb_dts_buffer; | |
int got_output; | |
} InputStream; | |
typedef struct LastFrameDuration { | |
int stream_idx; | |
int64_t duration; | |
} LastFrameDuration; | |
typedef struct InputFile { | |
int index; | |
AVFormatContext *ctx; | |
int eof_reached; /* true if eof reached */ | |
int eagain; /* true if last read attempt returned EAGAIN */ | |
int64_t input_ts_offset; | |
int input_sync_ref; | |
/** | |
* Effective format start time based on enabled streams. | |
*/ | |
int64_t start_time_effective; | |
int64_t ts_offset; | |
/** | |
* Extra timestamp offset added by discontinuity handling. | |
*/ | |
int64_t ts_offset_discont; | |
int64_t last_ts; | |
int64_t start_time; /* user-specified start time in AV_TIME_BASE or AV_NOPTS_VALUE */ | |
int64_t recording_time; | |
/* streams that ffmpeg is aware of; | |
* there may be extra streams in ctx that are not mapped to an InputStream | |
* if new streams appear dynamically during demuxing */ | |
InputStream **streams; | |
int nb_streams; | |
int rate_emu; | |
float readrate; | |
int accurate_seek; | |
/* when looping the input file, this queue is used by decoders to report | |
* the last frame duration back to the demuxer thread */ | |
AVThreadMessageQueue *audio_duration_queue; | |
int audio_duration_queue_size; | |
} InputFile; | |
enum forced_keyframes_const { | |
FKF_N, | |
FKF_N_FORCED, | |
FKF_PREV_FORCED_N, | |
FKF_PREV_FORCED_T, | |
FKF_T, | |
FKF_NB | |
}; | |
enum EncStatsType { | |
ENC_STATS_LITERAL = 0, | |
ENC_STATS_FILE_IDX, | |
ENC_STATS_STREAM_IDX, | |
ENC_STATS_FRAME_NUM, | |
ENC_STATS_FRAME_NUM_IN, | |
ENC_STATS_TIMEBASE, | |
ENC_STATS_TIMEBASE_IN, | |
ENC_STATS_PTS, | |
ENC_STATS_PTS_TIME, | |
ENC_STATS_PTS_IN, | |
ENC_STATS_PTS_TIME_IN, | |
ENC_STATS_DTS, | |
ENC_STATS_DTS_TIME, | |
ENC_STATS_SAMPLE_NUM, | |
ENC_STATS_NB_SAMPLES, | |
ENC_STATS_PKT_SIZE, | |
ENC_STATS_BITRATE, | |
ENC_STATS_AVG_BITRATE, | |
}; | |
typedef struct EncStatsComponent { | |
enum EncStatsType type; | |
uint8_t *str; | |
size_t str_len; | |
} EncStatsComponent; | |
typedef struct EncStats { | |
EncStatsComponent *components; | |
int nb_components; | |
AVIOContext *io; | |
} EncStats; | |
extern const char *const forced_keyframes_const_names[]; | |
typedef enum { | |
ENCODER_FINISHED = 1, | |
MUXER_FINISHED = 2, | |
} OSTFinished ; | |
enum { | |
KF_FORCE_SOURCE = 1, | |
KF_FORCE_SOURCE_NO_DROP = 2, | |
}; | |
typedef struct KeyframeForceCtx { | |
int type; | |
int64_t ref_pts; | |
// timestamps of the forced keyframes, in AV_TIME_BASE_Q | |
int64_t *pts; | |
int nb_pts; | |
int index; | |
AVExpr *pexpr; | |
double expr_const_values[FKF_NB]; | |
int dropped_keyframe; | |
} KeyframeForceCtx; | |
typedef struct OutputStream { | |
const AVClass *class; | |
int file_index; /* file index */ | |
int index; /* stream index in the output file */ | |
/* input stream that is the source for this output stream; | |
* may be NULL for streams with no well-defined source, e.g. | |
* attachments or outputs from complex filtergraphs */ | |
InputStream *ist; | |
AVStream *st; /* stream in the output file */ | |
/* number of frames emitted by the video-encoding sync code */ | |
int64_t vsync_frame_number; | |
/* predicted pts of the next frame to be encoded | |
* audio/video encoding only */ | |
int64_t next_pts; | |
/* dts of the last packet sent to the muxing queue, in AV_TIME_BASE_Q */ | |
int64_t last_mux_dts; | |
/* pts of the last frame received from the filters, in AV_TIME_BASE_Q */ | |
int64_t last_filter_pts; | |
// timestamp from which the streamcopied streams should start, | |
// in AV_TIME_BASE_Q; | |
// everything before it should be discarded | |
int64_t ts_copy_start; | |
// the timebase of the packets sent to the muxer | |
AVRational mux_timebase; | |
AVRational enc_timebase; | |
AVCodecContext *enc_ctx; | |
AVFrame *filtered_frame; | |
AVFrame *last_frame; | |
AVFrame *sq_frame; | |
AVPacket *pkt; | |
int64_t last_dropped; | |
int64_t last_nb0_frames[3]; | |
/* video only */ | |
AVRational frame_rate; | |
AVRational max_frame_rate; | |
enum VideoSyncMethod vsync_method; | |
int is_cfr; | |
int force_fps; | |
int top_field_first; | |
int rotate_overridden; | |
int autoscale; | |
int bitexact; | |
int bits_per_raw_sample; | |
double rotate_override_value; | |
AVRational frame_aspect_ratio; | |
KeyframeForceCtx kf; | |
/* audio only */ | |
int *audio_channels_map; /* list of the channels id to pick from the source stream */ | |
int audio_channels_mapped; /* number of channels in audio_channels_map */ | |
char *logfile_prefix; | |
FILE *logfile; | |
OutputFilter *filter; | |
char *avfilter; | |
char *filters; ///< filtergraph associated to the -filter option | |
char *filters_script; ///< filtergraph script associated to the -filter_script option | |
AVDictionary *encoder_opts; | |
AVDictionary *sws_dict; | |
AVDictionary *swr_opts; | |
char *apad; | |
OSTFinished finished; /* no more packets should be written for this stream */ | |
int unavailable; /* true if the steram is unavailable (possibly temporarily) */ | |
// init_output_stream() has been called for this stream | |
// The encoder and the bitstream filters have been initialized and the stream | |
// parameters are set in the AVStream. | |
int initialized; | |
int inputs_done; | |
const char *attachment_filename; | |
int streamcopy_started; | |
int copy_initial_nonkeyframes; | |
int copy_prior_start; | |
int keep_pix_fmt; | |
/* stats */ | |
// combined size of all the packets sent to the muxer | |
uint64_t data_size_mux; | |
// combined size of all the packets received from the encoder | |
uint64_t data_size_enc; | |
// number of packets send to the muxer | |
atomic_uint_least64_t packets_written; | |
// number of frames/samples sent to the encoder | |
uint64_t frames_encoded; | |
uint64_t samples_encoded; | |
// number of packets received from the encoder | |
uint64_t packets_encoded; | |
/* packet quality factor */ | |
int quality; | |
/* packet picture type */ | |
int pict_type; | |
/* frame encode sum of squared error values */ | |
int64_t error[4]; | |
int sq_idx_encode; | |
int sq_idx_mux; | |
EncStats enc_stats_pre; | |
EncStats enc_stats_post; | |
/* | |
* bool on whether this stream should be utilized for splitting | |
* subtitles utilizing fix_sub_duration at random access points. | |
*/ | |
unsigned int fix_sub_duration_heartbeat; | |
} OutputStream; | |
typedef struct OutputFile { | |
const AVClass *class; | |
int index; | |
const AVOutputFormat *format; | |
const char *url; | |
OutputStream **streams; | |
int nb_streams; | |
SyncQueue *sq_encode; | |
int64_t recording_time; ///< desired length of the resulting file in microseconds == AV_TIME_BASE units | |
int64_t start_time; ///< start time in microseconds == AV_TIME_BASE units | |
int shortest; | |
int bitexact; | |
} OutputFile; | |
extern InputFile **input_files; | |
extern int nb_input_files; | |
extern OutputFile **output_files; | |
extern int nb_output_files; | |
extern FilterGraph **filtergraphs; | |
extern int nb_filtergraphs; | |
extern char *vstats_filename; | |
extern char *sdp_filename; | |
extern float audio_drift_threshold; | |
extern float dts_delta_threshold; | |
extern float dts_error_threshold; | |
extern enum VideoSyncMethod video_sync_method; | |
extern float frame_drop_threshold; | |
extern int do_benchmark; | |
extern int do_benchmark_all; | |
extern int do_hex_dump; | |
extern int do_pkt_dump; | |
extern int copy_ts; | |
extern int start_at_zero; | |
extern int copy_tb; | |
extern int debug_ts; | |
extern int exit_on_error; | |
extern int abort_on_flags; | |
extern int print_stats; | |
extern int64_t stats_period; | |
extern int qp_hist; | |
extern int stdin_interaction; | |
extern AVIOContext *progress_avio; | |
extern float max_error_rate; | |
extern char *filter_nbthreads; | |
extern int filter_complex_nbthreads; | |
extern int vstats_version; | |
extern int auto_conversion_filters; | |
extern const AVIOInterruptCB int_cb; | |
extern const OptionDef options[]; | |
extern HWDevice *filter_hw_device; | |
extern unsigned nb_output_dumped; | |
extern int main_return_code; | |
extern int ignore_unknown_streams; | |
extern int copy_unknown_streams; | |
extern int recast_media; | |
extern int do_psnr; | |
void term_init(void); | |
void term_exit(void); | |
void show_usage(void); | |
void remove_avoptions(AVDictionary **a, AVDictionary *b); | |
void assert_avoptions(AVDictionary *m); | |
void assert_file_overwrite(const char *filename); | |
char *file_read(const char *filename); | |
AVDictionary *strip_specifiers(const AVDictionary *dict); | |
const AVCodec *find_codec_or_die(void *logctx, const char *name, | |
enum AVMediaType type, int encoder); | |
int parse_and_set_vsync(const char *arg, int *vsync_var, int file_idx, int st_idx, int is_global); | |
int configure_filtergraph(FilterGraph *fg); | |
void check_filter_outputs(void); | |
int filtergraph_is_simple(FilterGraph *fg); | |
int init_simple_filtergraph(InputStream *ist, OutputStream *ost); | |
int init_complex_filtergraph(FilterGraph *fg); | |
void sub2video_update(InputStream *ist, int64_t heartbeat_pts, AVSubtitle *sub); | |
int ifilter_parameters_from_frame(InputFilter *ifilter, const AVFrame *frame); | |
int ffmpeg_parse_options(int argc, char **argv); | |
void enc_stats_write(OutputStream *ost, EncStats *es, | |
const AVFrame *frame, const AVPacket *pkt, | |
uint64_t frame_num); | |
HWDevice *hw_device_get_by_name(const char *name); | |
int hw_device_init_from_string(const char *arg, HWDevice **dev); | |
void hw_device_free_all(void); | |
int hw_device_setup_for_decode(InputStream *ist); | |
int hw_device_setup_for_encode(OutputStream *ost); | |
int hw_device_setup_for_filter(FilterGraph *fg); | |
int hwaccel_decode_init(AVCodecContext *avctx); | |
/* | |
* Initialize muxing state for the given stream, should be called | |
* after the codec/streamcopy setup has been done. | |
* | |
* Open the muxer once all the streams have been initialized. | |
*/ | |
int of_stream_init(OutputFile *of, OutputStream *ost); | |
int of_write_trailer(OutputFile *of); | |
int of_open(const OptionsContext *o, const char *filename); | |
void of_close(OutputFile **pof); | |
void of_enc_stats_close(void); | |
/* | |
* Send a single packet to the output, applying any bitstream filters | |
* associated with the output stream. This may result in any number | |
* of packets actually being written, depending on what bitstream | |
* filters are applied. The supplied packet is consumed and will be | |
* blank (as if newly-allocated) when this function returns. | |
* | |
* If eof is set, instead indicate EOF to all bitstream filters and | |
* therefore flush any delayed packets to the output. A blank packet | |
* must be supplied in this case. | |
*/ | |
void of_output_packet(OutputFile *of, AVPacket *pkt, OutputStream *ost, int eof); | |
int64_t of_filesize(OutputFile *of); | |
int ifile_open(const OptionsContext *o, const char *filename); | |
void ifile_close(InputFile **f); | |
/** | |
* Get next input packet from the demuxer. | |
* | |
* @param pkt the packet is written here when this function returns 0 | |
* @return | |
* - 0 when a packet has been read successfully | |
* - 1 when stream end was reached, but the stream is looped; | |
* caller should flush decoders and read from this demuxer again | |
* - a negative error code on failure | |
*/ | |
int ifile_get_packet(InputFile *f, AVPacket **pkt); | |
/* iterate over all input streams in all input files; | |
* pass NULL to start iteration */ | |
InputStream *ist_iter(InputStream *prev); | |
extern const char * const opt_name_codec_names[]; | |
extern const char * const opt_name_codec_tags[]; | |
extern const char * const opt_name_frame_rates[]; | |
extern const char * const opt_name_top_field_first[]; | |