Search in sources :

Example 1 with Part

use of androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist.Part in project media by androidx.

the class HlsChunkSource method getNextMediaSequenceAndPartIndex.

// Private methods.
/**
 * Returns the media sequence number and part index to load next in the {@code mediaPlaylist}.
 *
 * @param previous The last (at least partially) loaded segment.
 * @param switchingTrack Whether the segment to load is not preceded by a segment in the same
 *     track.
 * @param mediaPlaylist The media playlist to which the segment to load belongs.
 * @param startOfPlaylistInPeriodUs The start of {@code mediaPlaylist} relative to the period
 *     start in microseconds.
 * @param loadPositionUs The current load position relative to the period start in microseconds.
 * @return The media sequence and part index to load.
 */
private Pair<Long, Integer> getNextMediaSequenceAndPartIndex(@Nullable HlsMediaChunk previous, boolean switchingTrack, HlsMediaPlaylist mediaPlaylist, long startOfPlaylistInPeriodUs, long loadPositionUs) {
    if (previous == null || switchingTrack) {
        long endOfPlaylistInPeriodUs = startOfPlaylistInPeriodUs + mediaPlaylist.durationUs;
        long targetPositionInPeriodUs = (previous == null || independentSegments) ? loadPositionUs : previous.startTimeUs;
        if (!mediaPlaylist.hasEndTag && targetPositionInPeriodUs >= endOfPlaylistInPeriodUs) {
            // If the playlist is too old to contain the chunk, we need to refresh it.
            return new Pair<>(mediaPlaylist.mediaSequence + mediaPlaylist.segments.size(), /* partIndex */
            C.INDEX_UNSET);
        }
        long targetPositionInPlaylistUs = targetPositionInPeriodUs - startOfPlaylistInPeriodUs;
        int segmentIndexInPlaylist = Util.binarySearchFloor(mediaPlaylist.segments, /* value= */
        targetPositionInPlaylistUs, /* inclusive= */
        true, /* stayInBounds= */
        !playlistTracker.isLive() || previous == null);
        long mediaSequence = segmentIndexInPlaylist + mediaPlaylist.mediaSequence;
        int partIndex = C.INDEX_UNSET;
        if (segmentIndexInPlaylist >= 0) {
            // In case we are inside the live window, we try to pick a part if available.
            Segment segment = mediaPlaylist.segments.get(segmentIndexInPlaylist);
            List<HlsMediaPlaylist.Part> parts = targetPositionInPlaylistUs < segment.relativeStartTimeUs + segment.durationUs ? segment.parts : mediaPlaylist.trailingParts;
            for (int i = 0; i < parts.size(); i++) {
                HlsMediaPlaylist.Part part = parts.get(i);
                if (targetPositionInPlaylistUs < part.relativeStartTimeUs + part.durationUs) {
                    if (part.isIndependent) {
                        partIndex = i;
                        // Increase media sequence by one if the part is a trailing part.
                        mediaSequence += parts == mediaPlaylist.trailingParts ? 1 : 0;
                    }
                    break;
                }
            }
        }
        return new Pair<>(mediaSequence, partIndex);
    }
    // If loading has not completed, we return the previous chunk again.
    return (previous.isLoadCompleted() ? new Pair<>(previous.partIndex == C.INDEX_UNSET ? previous.getNextChunkIndex() : previous.chunkIndex, previous.partIndex == C.INDEX_UNSET ? C.INDEX_UNSET : previous.partIndex + 1) : new Pair<>(previous.chunkIndex, previous.partIndex));
}
Also used : HlsMediaPlaylist(androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist) Segment(androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist.Segment) Pair(android.util.Pair)

Example 2 with Part

use of androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist.Part in project media by androidx.

the class HlsSampleStreamWrapper method selectTracks.

/**
 * Called by the parent {@link HlsMediaPeriod} when a track selection occurs.
 *
 * @param selections The renderer track selections.
 * @param mayRetainStreamFlags Flags indicating whether the existing sample stream can be retained
 *     for each selection. A {@code true} value indicates that the selection is unchanged, and
 *     that the caller does not require that the sample stream be recreated.
 * @param streams The existing sample streams, which will be updated to reflect the provided
 *     selections.
 * @param streamResetFlags Will be updated to indicate new sample streams, and sample streams that
 *     have been retained but with the requirement that the consuming renderer be reset.
 * @param positionUs The current playback position in microseconds.
 * @param forceReset If true then a reset is forced (i.e. a seek will be performed with in-buffer
 *     seeking disabled).
 * @return Whether this wrapper requires the parent {@link HlsMediaPeriod} to perform a seek as
 *     part of the track selection.
 */
public boolean selectTracks(@NullableType ExoTrackSelection[] selections, boolean[] mayRetainStreamFlags, @NullableType SampleStream[] streams, boolean[] streamResetFlags, long positionUs, boolean forceReset) {
    assertIsPrepared();
    int oldEnabledTrackGroupCount = enabledTrackGroupCount;
    // Deselect old tracks.
    for (int i = 0; i < selections.length; i++) {
        HlsSampleStream stream = (HlsSampleStream) streams[i];
        if (stream != null && (selections[i] == null || !mayRetainStreamFlags[i])) {
            enabledTrackGroupCount--;
            stream.unbindSampleQueue();
            streams[i] = null;
        }
    }
    // We'll always need to seek if we're being forced to reset, or if this is a first selection to
    // a position other than the one we started preparing with, or if we're making a selection
    // having previously disabled all tracks.
    boolean seekRequired = forceReset || (seenFirstTrackSelection ? oldEnabledTrackGroupCount == 0 : positionUs != lastSeekPositionUs);
    // Get the old (i.e. current before the loop below executes) primary track selection. The new
    // primary selection will equal the old one unless it's changed in the loop.
    ExoTrackSelection oldPrimaryTrackSelection = chunkSource.getTrackSelection();
    ExoTrackSelection primaryTrackSelection = oldPrimaryTrackSelection;
    // Select new tracks.
    for (int i = 0; i < selections.length; i++) {
        ExoTrackSelection selection = selections[i];
        if (selection == null) {
            continue;
        }
        int trackGroupIndex = trackGroups.indexOf(selection.getTrackGroup());
        if (trackGroupIndex == primaryTrackGroupIndex) {
            primaryTrackSelection = selection;
            chunkSource.setTrackSelection(selection);
        }
        if (streams[i] == null) {
            enabledTrackGroupCount++;
            streams[i] = new HlsSampleStream(this, trackGroupIndex);
            streamResetFlags[i] = true;
            if (trackGroupToSampleQueueIndex != null) {
                ((HlsSampleStream) streams[i]).bindSampleQueue();
                // If there's still a chance of avoiding a seek, try and seek within the sample queue.
                if (!seekRequired) {
                    SampleQueue sampleQueue = sampleQueues[trackGroupToSampleQueueIndex[trackGroupIndex]];
                    // A seek can be avoided if we're able to seek to the current playback position in
                    // the sample queue, or if we haven't read anything from the queue since the previous
                    // seek (this case is common for sparse tracks such as metadata tracks). In all other
                    // cases a seek is required.
                    seekRequired = !sampleQueue.seekTo(positionUs, /* allowTimeBeyondBuffer= */
                    true) && sampleQueue.getReadIndex() != 0;
                }
            }
        }
    }
    if (enabledTrackGroupCount == 0) {
        chunkSource.reset();
        downstreamTrackFormat = null;
        pendingResetUpstreamFormats = true;
        mediaChunks.clear();
        if (loader.isLoading()) {
            if (sampleQueuesBuilt) {
                // Discard as much as we can synchronously.
                for (SampleQueue sampleQueue : sampleQueues) {
                    sampleQueue.discardToEnd();
                }
            }
            loader.cancelLoading();
        } else {
            resetSampleQueues();
        }
    } else {
        if (!mediaChunks.isEmpty() && !Util.areEqual(primaryTrackSelection, oldPrimaryTrackSelection)) {
            // The primary track selection has changed and we have buffered media. The buffered media
            // may need to be discarded.
            boolean primarySampleQueueDirty = false;
            if (!seenFirstTrackSelection) {
                long bufferedDurationUs = positionUs < 0 ? -positionUs : 0;
                HlsMediaChunk lastMediaChunk = getLastMediaChunk();
                MediaChunkIterator[] mediaChunkIterators = chunkSource.createMediaChunkIterators(lastMediaChunk, positionUs);
                primaryTrackSelection.updateSelectedTrack(positionUs, bufferedDurationUs, C.TIME_UNSET, readOnlyMediaChunks, mediaChunkIterators);
                int chunkIndex = chunkSource.getTrackGroup().indexOf(lastMediaChunk.trackFormat);
                if (primaryTrackSelection.getSelectedIndexInTrackGroup() != chunkIndex) {
                    // This is the first selection and the chunk loaded during preparation does not match
                    // the initially selected format.
                    primarySampleQueueDirty = true;
                }
            } else {
                // The primary sample queue contains media buffered for the old primary track selection.
                primarySampleQueueDirty = true;
            }
            if (primarySampleQueueDirty) {
                forceReset = true;
                seekRequired = true;
                pendingResetUpstreamFormats = true;
            }
        }
        if (seekRequired) {
            seekToUs(positionUs, forceReset);
            // We'll need to reset renderers consuming from all streams due to the seek.
            for (int i = 0; i < streams.length; i++) {
                if (streams[i] != null) {
                    streamResetFlags[i] = true;
                }
            }
        }
    }
    updateSampleStreams(streams);
    seenFirstTrackSelection = true;
    return seekRequired;
}
Also used : SampleQueue(androidx.media3.exoplayer.source.SampleQueue) MediaChunkIterator(androidx.media3.exoplayer.source.chunk.MediaChunkIterator) ExoTrackSelection(androidx.media3.exoplayer.trackselection.ExoTrackSelection)

Example 3 with Part

use of androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist.Part in project media by androidx.

the class HlsPlaylistParser method parseMediaPlaylist.

private static HlsMediaPlaylist parseMediaPlaylist(HlsMultivariantPlaylist multivariantPlaylist, @Nullable HlsMediaPlaylist previousMediaPlaylist, LineIterator iterator, String baseUri) throws IOException {
    @HlsMediaPlaylist.PlaylistType int playlistType = HlsMediaPlaylist.PLAYLIST_TYPE_UNKNOWN;
    long startOffsetUs = C.TIME_UNSET;
    long mediaSequence = 0;
    // Default version == 1.
    int version = 1;
    long targetDurationUs = C.TIME_UNSET;
    long partTargetDurationUs = C.TIME_UNSET;
    boolean hasIndependentSegmentsTag = multivariantPlaylist.hasIndependentSegments;
    boolean hasEndTag = false;
    @Nullable Segment initializationSegment = null;
    HashMap<String, String> variableDefinitions = new HashMap<>();
    HashMap<String, Segment> urlToInferredInitSegment = new HashMap<>();
    List<Segment> segments = new ArrayList<>();
    List<Part> trailingParts = new ArrayList<>();
    @Nullable Part preloadPart = null;
    List<RenditionReport> renditionReports = new ArrayList<>();
    List<String> tags = new ArrayList<>();
    long segmentDurationUs = 0;
    String segmentTitle = "";
    boolean hasDiscontinuitySequence = false;
    int playlistDiscontinuitySequence = 0;
    int relativeDiscontinuitySequence = 0;
    long playlistStartTimeUs = 0;
    long segmentStartTimeUs = 0;
    boolean preciseStart = false;
    long segmentByteRangeOffset = 0;
    long segmentByteRangeLength = C.LENGTH_UNSET;
    long partStartTimeUs = 0;
    long partByteRangeOffset = 0;
    boolean isIFrameOnly = false;
    long segmentMediaSequence = 0;
    boolean hasGapTag = false;
    HlsMediaPlaylist.ServerControl serverControl = new HlsMediaPlaylist.ServerControl(/* skipUntilUs= */
    C.TIME_UNSET, /* canSkipDateRanges= */
    false, /* holdBackUs= */
    C.TIME_UNSET, /* partHoldBackUs= */
    C.TIME_UNSET, /* canBlockReload= */
    false);
    @Nullable DrmInitData playlistProtectionSchemes = null;
    @Nullable String fullSegmentEncryptionKeyUri = null;
    @Nullable String fullSegmentEncryptionIV = null;
    TreeMap<String, SchemeData> currentSchemeDatas = new TreeMap<>();
    @Nullable String encryptionScheme = null;
    @Nullable DrmInitData cachedDrmInitData = null;
    String line;
    while (iterator.hasNext()) {
        line = iterator.next();
        if (line.startsWith(TAG_PREFIX)) {
            // We expose all tags through the playlist.
            tags.add(line);
        }
        if (line.startsWith(TAG_PLAYLIST_TYPE)) {
            String playlistTypeString = parseStringAttr(line, REGEX_PLAYLIST_TYPE, variableDefinitions);
            if ("VOD".equals(playlistTypeString)) {
                playlistType = HlsMediaPlaylist.PLAYLIST_TYPE_VOD;
            } else if ("EVENT".equals(playlistTypeString)) {
                playlistType = HlsMediaPlaylist.PLAYLIST_TYPE_EVENT;
            }
        } else if (line.equals(TAG_IFRAME)) {
            isIFrameOnly = true;
        } else if (line.startsWith(TAG_START)) {
            startOffsetUs = (long) (parseDoubleAttr(line, REGEX_TIME_OFFSET) * C.MICROS_PER_SECOND);
            preciseStart = parseOptionalBooleanAttribute(line, REGEX_PRECISE, /* defaultValue= */
            false);
        } else if (line.startsWith(TAG_SERVER_CONTROL)) {
            serverControl = parseServerControl(line);
        } else if (line.startsWith(TAG_PART_INF)) {
            double partTargetDurationSeconds = parseDoubleAttr(line, REGEX_PART_TARGET_DURATION);
            partTargetDurationUs = (long) (partTargetDurationSeconds * C.MICROS_PER_SECOND);
        } else if (line.startsWith(TAG_INIT_SEGMENT)) {
            String uri = parseStringAttr(line, REGEX_URI, variableDefinitions);
            String byteRange = parseOptionalStringAttr(line, REGEX_ATTR_BYTERANGE, variableDefinitions);
            if (byteRange != null) {
                String[] splitByteRange = Util.split(byteRange, "@");
                segmentByteRangeLength = Long.parseLong(splitByteRange[0]);
                if (splitByteRange.length > 1) {
                    segmentByteRangeOffset = Long.parseLong(splitByteRange[1]);
                }
            }
            if (segmentByteRangeLength == C.LENGTH_UNSET) {
                // The segment has no byte range defined.
                segmentByteRangeOffset = 0;
            }
            if (fullSegmentEncryptionKeyUri != null && fullSegmentEncryptionIV == null) {
                // See RFC 8216, Section 4.3.2.5.
                throw ParserException.createForMalformedManifest("The encryption IV attribute must be present when an initialization segment is" + " encrypted with METHOD=AES-128.", /* cause= */
                null);
            }
            initializationSegment = new Segment(uri, segmentByteRangeOffset, segmentByteRangeLength, fullSegmentEncryptionKeyUri, fullSegmentEncryptionIV);
            if (segmentByteRangeLength != C.LENGTH_UNSET) {
                segmentByteRangeOffset += segmentByteRangeLength;
            }
            segmentByteRangeLength = C.LENGTH_UNSET;
        } else if (line.startsWith(TAG_TARGET_DURATION)) {
            targetDurationUs = parseIntAttr(line, REGEX_TARGET_DURATION) * C.MICROS_PER_SECOND;
        } else if (line.startsWith(TAG_MEDIA_SEQUENCE)) {
            mediaSequence = parseLongAttr(line, REGEX_MEDIA_SEQUENCE);
            segmentMediaSequence = mediaSequence;
        } else if (line.startsWith(TAG_VERSION)) {
            version = parseIntAttr(line, REGEX_VERSION);
        } else if (line.startsWith(TAG_DEFINE)) {
            String importName = parseOptionalStringAttr(line, REGEX_IMPORT, variableDefinitions);
            if (importName != null) {
                String value = multivariantPlaylist.variableDefinitions.get(importName);
                if (value != null) {
                    variableDefinitions.put(importName, value);
                } else {
                // The multivariant playlist does not declare the imported variable. Ignore.
                }
            } else {
                variableDefinitions.put(parseStringAttr(line, REGEX_NAME, variableDefinitions), parseStringAttr(line, REGEX_VALUE, variableDefinitions));
            }
        } else if (line.startsWith(TAG_MEDIA_DURATION)) {
            segmentDurationUs = parseTimeSecondsToUs(line, REGEX_MEDIA_DURATION);
            segmentTitle = parseOptionalStringAttr(line, REGEX_MEDIA_TITLE, "", variableDefinitions);
        } else if (line.startsWith(TAG_SKIP)) {
            int skippedSegmentCount = parseIntAttr(line, REGEX_SKIPPED_SEGMENTS);
            checkState(previousMediaPlaylist != null && segments.isEmpty());
            int startIndex = (int) (mediaSequence - castNonNull(previousMediaPlaylist).mediaSequence);
            int endIndex = startIndex + skippedSegmentCount;
            if (startIndex < 0 || endIndex > previousMediaPlaylist.segments.size()) {
                // Throw to force a reload if not all segments are available in the previous playlist.
                throw new DeltaUpdateException();
            }
            for (int i = startIndex; i < endIndex; i++) {
                Segment segment = previousMediaPlaylist.segments.get(i);
                if (mediaSequence != previousMediaPlaylist.mediaSequence) {
                    // If the media sequences of the playlists are not the same, we need to recreate the
                    // object with the updated relative start time and the relative discontinuity
                    // sequence. With identical playlist media sequences these values do not change.
                    int newRelativeDiscontinuitySequence = previousMediaPlaylist.discontinuitySequence - playlistDiscontinuitySequence + segment.relativeDiscontinuitySequence;
                    segment = segment.copyWith(segmentStartTimeUs, newRelativeDiscontinuitySequence);
                }
                segments.add(segment);
                segmentStartTimeUs += segment.durationUs;
                partStartTimeUs = segmentStartTimeUs;
                if (segment.byteRangeLength != C.LENGTH_UNSET) {
                    segmentByteRangeOffset = segment.byteRangeOffset + segment.byteRangeLength;
                }
                relativeDiscontinuitySequence = segment.relativeDiscontinuitySequence;
                initializationSegment = segment.initializationSegment;
                cachedDrmInitData = segment.drmInitData;
                fullSegmentEncryptionKeyUri = segment.fullSegmentEncryptionKeyUri;
                if (segment.encryptionIV == null || !segment.encryptionIV.equals(Long.toHexString(segmentMediaSequence))) {
                    fullSegmentEncryptionIV = segment.encryptionIV;
                }
                segmentMediaSequence++;
            }
        } else if (line.startsWith(TAG_KEY)) {
            String method = parseStringAttr(line, REGEX_METHOD, variableDefinitions);
            String keyFormat = parseOptionalStringAttr(line, REGEX_KEYFORMAT, KEYFORMAT_IDENTITY, variableDefinitions);
            fullSegmentEncryptionKeyUri = null;
            fullSegmentEncryptionIV = null;
            if (METHOD_NONE.equals(method)) {
                currentSchemeDatas.clear();
                cachedDrmInitData = null;
            } else /* !METHOD_NONE.equals(method) */
            {
                fullSegmentEncryptionIV = parseOptionalStringAttr(line, REGEX_IV, variableDefinitions);
                if (KEYFORMAT_IDENTITY.equals(keyFormat)) {
                    if (METHOD_AES_128.equals(method)) {
                        // The segment is fully encrypted using an identity key.
                        fullSegmentEncryptionKeyUri = parseStringAttr(line, REGEX_URI, variableDefinitions);
                    } else {
                    // Do nothing. Samples are encrypted using an identity key, but this is not supported.
                    // Hopefully, a traditional DRM alternative is also provided.
                    }
                } else {
                    if (encryptionScheme == null) {
                        encryptionScheme = parseEncryptionScheme(method);
                    }
                    SchemeData schemeData = parseDrmSchemeData(line, keyFormat, variableDefinitions);
                    if (schemeData != null) {
                        cachedDrmInitData = null;
                        currentSchemeDatas.put(keyFormat, schemeData);
                    }
                }
            }
        } else if (line.startsWith(TAG_BYTERANGE)) {
            String byteRange = parseStringAttr(line, REGEX_BYTERANGE, variableDefinitions);
            String[] splitByteRange = Util.split(byteRange, "@");
            segmentByteRangeLength = Long.parseLong(splitByteRange[0]);
            if (splitByteRange.length > 1) {
                segmentByteRangeOffset = Long.parseLong(splitByteRange[1]);
            }
        } else if (line.startsWith(TAG_DISCONTINUITY_SEQUENCE)) {
            hasDiscontinuitySequence = true;
            playlistDiscontinuitySequence = Integer.parseInt(line.substring(line.indexOf(':') + 1));
        } else if (line.equals(TAG_DISCONTINUITY)) {
            relativeDiscontinuitySequence++;
        } else if (line.startsWith(TAG_PROGRAM_DATE_TIME)) {
            if (playlistStartTimeUs == 0) {
                long programDatetimeUs = Util.msToUs(Util.parseXsDateTime(line.substring(line.indexOf(':') + 1)));
                playlistStartTimeUs = programDatetimeUs - segmentStartTimeUs;
            }
        } else if (line.equals(TAG_GAP)) {
            hasGapTag = true;
        } else if (line.equals(TAG_INDEPENDENT_SEGMENTS)) {
            hasIndependentSegmentsTag = true;
        } else if (line.equals(TAG_ENDLIST)) {
            hasEndTag = true;
        } else if (line.startsWith(TAG_RENDITION_REPORT)) {
            long lastMediaSequence = parseOptionalLongAttr(line, REGEX_LAST_MSN, C.INDEX_UNSET);
            int lastPartIndex = parseOptionalIntAttr(line, REGEX_LAST_PART, C.INDEX_UNSET);
            String uri = parseStringAttr(line, REGEX_URI, variableDefinitions);
            Uri playlistUri = Uri.parse(UriUtil.resolve(baseUri, uri));
            renditionReports.add(new RenditionReport(playlistUri, lastMediaSequence, lastPartIndex));
        } else if (line.startsWith(TAG_PRELOAD_HINT)) {
            if (preloadPart != null) {
                continue;
            }
            String type = parseStringAttr(line, REGEX_PRELOAD_HINT_TYPE, variableDefinitions);
            if (!TYPE_PART.equals(type)) {
                continue;
            }
            String url = parseStringAttr(line, REGEX_URI, variableDefinitions);
            long byteRangeStart = parseOptionalLongAttr(line, REGEX_BYTERANGE_START, /* defaultValue= */
            C.LENGTH_UNSET);
            long byteRangeLength = parseOptionalLongAttr(line, REGEX_BYTERANGE_LENGTH, /* defaultValue= */
            C.LENGTH_UNSET);
            @Nullable String segmentEncryptionIV = getSegmentEncryptionIV(segmentMediaSequence, fullSegmentEncryptionKeyUri, fullSegmentEncryptionIV);
            if (cachedDrmInitData == null && !currentSchemeDatas.isEmpty()) {
                SchemeData[] schemeDatas = currentSchemeDatas.values().toArray(new SchemeData[0]);
                cachedDrmInitData = new DrmInitData(encryptionScheme, schemeDatas);
                if (playlistProtectionSchemes == null) {
                    playlistProtectionSchemes = getPlaylistProtectionSchemes(encryptionScheme, schemeDatas);
                }
            }
            if (byteRangeStart == C.LENGTH_UNSET || byteRangeLength != C.LENGTH_UNSET) {
                // Skip preload part if it is an unbounded range request.
                preloadPart = new Part(url, initializationSegment, /* durationUs= */
                0, relativeDiscontinuitySequence, partStartTimeUs, cachedDrmInitData, fullSegmentEncryptionKeyUri, segmentEncryptionIV, byteRangeStart != C.LENGTH_UNSET ? byteRangeStart : 0, byteRangeLength, /* hasGapTag= */
                false, /* isIndependent= */
                false, /* isPreload= */
                true);
            }
        } else if (line.startsWith(TAG_PART)) {
            @Nullable String segmentEncryptionIV = getSegmentEncryptionIV(segmentMediaSequence, fullSegmentEncryptionKeyUri, fullSegmentEncryptionIV);
            String url = parseStringAttr(line, REGEX_URI, variableDefinitions);
            long partDurationUs = (long) (parseDoubleAttr(line, REGEX_ATTR_DURATION) * C.MICROS_PER_SECOND);
            boolean isIndependent = parseOptionalBooleanAttribute(line, REGEX_INDEPENDENT, /* defaultValue= */
            false);
            // The first part of a segment is always independent if the segments are independent.
            isIndependent |= hasIndependentSegmentsTag && trailingParts.isEmpty();
            boolean isGap = parseOptionalBooleanAttribute(line, REGEX_GAP, /* defaultValue= */
            false);
            @Nullable String byteRange = parseOptionalStringAttr(line, REGEX_ATTR_BYTERANGE, variableDefinitions);
            long partByteRangeLength = C.LENGTH_UNSET;
            if (byteRange != null) {
                String[] splitByteRange = Util.split(byteRange, "@");
                partByteRangeLength = Long.parseLong(splitByteRange[0]);
                if (splitByteRange.length > 1) {
                    partByteRangeOffset = Long.parseLong(splitByteRange[1]);
                }
            }
            if (partByteRangeLength == C.LENGTH_UNSET) {
                partByteRangeOffset = 0;
            }
            if (cachedDrmInitData == null && !currentSchemeDatas.isEmpty()) {
                SchemeData[] schemeDatas = currentSchemeDatas.values().toArray(new SchemeData[0]);
                cachedDrmInitData = new DrmInitData(encryptionScheme, schemeDatas);
                if (playlistProtectionSchemes == null) {
                    playlistProtectionSchemes = getPlaylistProtectionSchemes(encryptionScheme, schemeDatas);
                }
            }
            trailingParts.add(new Part(url, initializationSegment, partDurationUs, relativeDiscontinuitySequence, partStartTimeUs, cachedDrmInitData, fullSegmentEncryptionKeyUri, segmentEncryptionIV, partByteRangeOffset, partByteRangeLength, isGap, isIndependent, /* isPreload= */
            false));
            partStartTimeUs += partDurationUs;
            if (partByteRangeLength != C.LENGTH_UNSET) {
                partByteRangeOffset += partByteRangeLength;
            }
        } else if (!line.startsWith("#")) {
            @Nullable String segmentEncryptionIV = getSegmentEncryptionIV(segmentMediaSequence, fullSegmentEncryptionKeyUri, fullSegmentEncryptionIV);
            segmentMediaSequence++;
            String segmentUri = replaceVariableReferences(line, variableDefinitions);
            @Nullable Segment inferredInitSegment = urlToInferredInitSegment.get(segmentUri);
            if (segmentByteRangeLength == C.LENGTH_UNSET) {
                // The segment has no byte range defined.
                segmentByteRangeOffset = 0;
            } else if (isIFrameOnly && initializationSegment == null && inferredInitSegment == null) {
                // The segment is a resource byte range without an initialization segment.
                // As per RFC 8216, Section 4.3.3.6, we assume the initialization section exists in the
                // bytes preceding the first segment in this segment's URL.
                // We assume the implicit initialization segment is unencrypted, since there's no way for
                // the playlist to provide an initialization vector for it.
                inferredInitSegment = new Segment(segmentUri, /* byteRangeOffset= */
                0, segmentByteRangeOffset, /* fullSegmentEncryptionKeyUri= */
                null, /* encryptionIV= */
                null);
                urlToInferredInitSegment.put(segmentUri, inferredInitSegment);
            }
            if (cachedDrmInitData == null && !currentSchemeDatas.isEmpty()) {
                SchemeData[] schemeDatas = currentSchemeDatas.values().toArray(new SchemeData[0]);
                cachedDrmInitData = new DrmInitData(encryptionScheme, schemeDatas);
                if (playlistProtectionSchemes == null) {
                    playlistProtectionSchemes = getPlaylistProtectionSchemes(encryptionScheme, schemeDatas);
                }
            }
            segments.add(new Segment(segmentUri, initializationSegment != null ? initializationSegment : inferredInitSegment, segmentTitle, segmentDurationUs, relativeDiscontinuitySequence, segmentStartTimeUs, cachedDrmInitData, fullSegmentEncryptionKeyUri, segmentEncryptionIV, segmentByteRangeOffset, segmentByteRangeLength, hasGapTag, trailingParts));
            segmentStartTimeUs += segmentDurationUs;
            partStartTimeUs = segmentStartTimeUs;
            segmentDurationUs = 0;
            segmentTitle = "";
            trailingParts = new ArrayList<>();
            if (segmentByteRangeLength != C.LENGTH_UNSET) {
                segmentByteRangeOffset += segmentByteRangeLength;
            }
            segmentByteRangeLength = C.LENGTH_UNSET;
            hasGapTag = false;
        }
    }
    Map<Uri, RenditionReport> renditionReportMap = new HashMap<>();
    for (int i = 0; i < renditionReports.size(); i++) {
        RenditionReport renditionReport = renditionReports.get(i);
        long lastMediaSequence = renditionReport.lastMediaSequence;
        if (lastMediaSequence == C.INDEX_UNSET) {
            lastMediaSequence = mediaSequence + segments.size() - (trailingParts.isEmpty() ? 1 : 0);
        }
        int lastPartIndex = renditionReport.lastPartIndex;
        if (lastPartIndex == C.INDEX_UNSET && partTargetDurationUs != C.TIME_UNSET) {
            List<Part> lastParts = trailingParts.isEmpty() ? Iterables.getLast(segments).parts : trailingParts;
            lastPartIndex = lastParts.size() - 1;
        }
        renditionReportMap.put(renditionReport.playlistUri, new RenditionReport(renditionReport.playlistUri, lastMediaSequence, lastPartIndex));
    }
    if (preloadPart != null) {
        trailingParts.add(preloadPart);
    }
    return new HlsMediaPlaylist(playlistType, baseUri, tags, startOffsetUs, preciseStart, playlistStartTimeUs, hasDiscontinuitySequence, playlistDiscontinuitySequence, mediaSequence, version, targetDurationUs, partTargetDurationUs, hasIndependentSegmentsTag, hasEndTag, /* hasProgramDateTime= */
    playlistStartTimeUs != 0, playlistProtectionSchemes, segments, trailingParts, serverControl, renditionReportMap);
}
Also used : HashMap(java.util.HashMap) ArrayList(java.util.ArrayList) RenditionReport(androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist.RenditionReport) SchemeData(androidx.media3.common.DrmInitData.SchemeData) Uri(android.net.Uri) Segment(androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist.Segment) DrmInitData(androidx.media3.common.DrmInitData) TreeMap(java.util.TreeMap) Part(androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist.Part) Nullable(androidx.annotation.Nullable)

Example 4 with Part

use of androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist.Part in project media by androidx.

the class HlsChunkSource method getSegmentBaseList.

// Package methods.
/**
 * Returns a list with all segment bases in the playlist starting from {@code mediaSequence} and
 * {@code partIndex} in the given playlist. The list may be empty if the starting point is not in
 * the playlist.
 */
@VisibleForTesting
static /* package */
List<HlsMediaPlaylist.SegmentBase> getSegmentBaseList(HlsMediaPlaylist playlist, long mediaSequence, int partIndex) {
    int firstSegmentIndexInPlaylist = (int) (mediaSequence - playlist.mediaSequence);
    if (firstSegmentIndexInPlaylist < 0 || playlist.segments.size() < firstSegmentIndexInPlaylist) {
        // The first media sequence is not in the playlist.
        return ImmutableList.of();
    }
    List<HlsMediaPlaylist.SegmentBase> segmentBases = new ArrayList<>();
    if (firstSegmentIndexInPlaylist < playlist.segments.size()) {
        if (partIndex != C.INDEX_UNSET) {
            // The iterator starts with a part that belongs to a segment.
            Segment firstSegment = playlist.segments.get(firstSegmentIndexInPlaylist);
            if (partIndex == 0) {
                // Use the full segment instead of the first part.
                segmentBases.add(firstSegment);
            } else if (partIndex < firstSegment.parts.size()) {
                // Add the parts from the first requested segment.
                segmentBases.addAll(firstSegment.parts.subList(partIndex, firstSegment.parts.size()));
            }
            firstSegmentIndexInPlaylist++;
        }
        partIndex = 0;
        // Add all remaining segments.
        segmentBases.addAll(playlist.segments.subList(firstSegmentIndexInPlaylist, playlist.segments.size()));
    }
    if (playlist.partTargetDurationUs != C.TIME_UNSET) {
        // That's a low latency playlist.
        partIndex = partIndex == C.INDEX_UNSET ? 0 : partIndex;
        if (partIndex < playlist.trailingParts.size()) {
            segmentBases.addAll(playlist.trailingParts.subList(partIndex, playlist.trailingParts.size()));
        }
    }
    return Collections.unmodifiableList(segmentBases);
}
Also used : ArrayList(java.util.ArrayList) Segment(androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist.Segment) VisibleForTesting(androidx.annotation.VisibleForTesting)

Example 5 with Part

use of androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist.Part in project media by androidx.

the class HlsChunkSource method getChunkPublicationState.

/**
 * Returns the publication state of the given chunk.
 *
 * @param mediaChunk The media chunk for which to evaluate the publication state.
 * @return Whether the media chunk is {@link #CHUNK_PUBLICATION_STATE_PRELOAD a preload chunk},
 *     has been {@link #CHUNK_PUBLICATION_STATE_REMOVED removed} or is definitely {@link
 *     #CHUNK_PUBLICATION_STATE_PUBLISHED published}.
 */
@ChunkPublicationState
public int getChunkPublicationState(HlsMediaChunk mediaChunk) {
    if (mediaChunk.partIndex == C.INDEX_UNSET) {
        // Chunks based on full segments can't be removed and are always published.
        return CHUNK_PUBLICATION_STATE_PUBLISHED;
    }
    Uri playlistUrl = playlistUrls[trackGroup.indexOf(mediaChunk.trackFormat)];
    HlsMediaPlaylist mediaPlaylist = checkNotNull(playlistTracker.getPlaylistSnapshot(playlistUrl, /* isForPlayback= */
    false));
    int segmentIndexInPlaylist = (int) (mediaChunk.chunkIndex - mediaPlaylist.mediaSequence);
    if (segmentIndexInPlaylist < 0) {
        // The parent segment of the previous chunk is not in the current playlist anymore.
        return CHUNK_PUBLICATION_STATE_PUBLISHED;
    }
    List<HlsMediaPlaylist.Part> partsInCurrentPlaylist = segmentIndexInPlaylist < mediaPlaylist.segments.size() ? mediaPlaylist.segments.get(segmentIndexInPlaylist).parts : mediaPlaylist.trailingParts;
    if (mediaChunk.partIndex >= partsInCurrentPlaylist.size()) {
        // sequence in the new playlist.
        return CHUNK_PUBLICATION_STATE_REMOVED;
    }
    HlsMediaPlaylist.Part newPart = partsInCurrentPlaylist.get(mediaChunk.partIndex);
    if (newPart.isPreload) {
        // The playlist did not change and the part in the new playlist is still a preload hint.
        return CHUNK_PUBLICATION_STATE_PRELOAD;
    }
    Uri newUri = Uri.parse(UriUtil.resolve(mediaPlaylist.baseUri, newPart.url));
    return Util.areEqual(newUri, mediaChunk.dataSpec.uri) ? CHUNK_PUBLICATION_STATE_PUBLISHED : CHUNK_PUBLICATION_STATE_REMOVED;
}
Also used : HlsMediaPlaylist(androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist) Uri(android.net.Uri)

Aggregations

Timeline (androidx.media3.common.Timeline)14 Test (org.junit.Test)14 MediaItem (androidx.media3.common.MediaItem)11 ArrayList (java.util.ArrayList)8 Nullable (androidx.annotation.Nullable)6 HlsMediaPlaylist (androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist)6 DataSpec (androidx.media3.datasource.DataSpec)5 Uri (android.net.Uri)3 Window (androidx.media3.common.Timeline.Window)3 Segment (androidx.media3.exoplayer.hls.playlist.HlsMediaPlaylist.Segment)3 MediaPeriodId (androidx.media3.exoplayer.source.MediaSource.MediaPeriodId)3 SurfaceTexture (android.graphics.SurfaceTexture)2 Pair (android.util.Pair)2 Surface (android.view.Surface)2 AdPlaybackState (androidx.media3.common.AdPlaybackState)2 DrmInitData (androidx.media3.common.DrmInitData)2 Player (androidx.media3.common.Player)2 Period (androidx.media3.common.Timeline.Period)2 RemotableTimeline (androidx.media3.common.Timeline.RemotableTimeline)2 ExoPlayer (androidx.media3.exoplayer.ExoPlayer)2