aboutsummaryrefslogtreecommitdiff
path: root/MediaBrowser.MediaEncoding/Subtitles/SubtitleEncoder.cs
diff options
context:
space:
mode:
Diffstat (limited to 'MediaBrowser.MediaEncoding/Subtitles/SubtitleEncoder.cs')
-rw-r--r--MediaBrowser.MediaEncoding/Subtitles/SubtitleEncoder.cs733
1 files changed, 733 insertions, 0 deletions
diff --git a/MediaBrowser.MediaEncoding/Subtitles/SubtitleEncoder.cs b/MediaBrowser.MediaEncoding/Subtitles/SubtitleEncoder.cs
new file mode 100644
index 000000000..d565ff3e2
--- /dev/null
+++ b/MediaBrowser.MediaEncoding/Subtitles/SubtitleEncoder.cs
@@ -0,0 +1,733 @@
+using MediaBrowser.Common.Configuration;
+using MediaBrowser.Common.Extensions;
+using MediaBrowser.Common.Net;
+using MediaBrowser.Controller.Entities;
+using MediaBrowser.Controller.Library;
+using MediaBrowser.Controller.MediaEncoding;
+using MediaBrowser.Model.Entities;
+using MediaBrowser.Model.Logging;
+using MediaBrowser.Model.MediaInfo;
+using MediaBrowser.Model.Serialization;
+using System;
+using System.Collections.Concurrent;
+using System.Diagnostics;
+using System.Globalization;
+using System.IO;
+using System.Linq;
+using System.Text;
+using System.Threading;
+using System.Threading.Tasks;
+using MediaBrowser.Model.IO;
+using MediaBrowser.Model.Diagnostics;
+using MediaBrowser.Model.Dto;
+using MediaBrowser.Model.Text;
+
+namespace MediaBrowser.MediaEncoding.Subtitles
+{
+ public class SubtitleEncoder : ISubtitleEncoder
+ {
+ private readonly ILibraryManager _libraryManager;
+ private readonly ILogger _logger;
+ private readonly IApplicationPaths _appPaths;
+ private readonly IFileSystem _fileSystem;
+ private readonly IMediaEncoder _mediaEncoder;
+ private readonly IJsonSerializer _json;
+ private readonly IHttpClient _httpClient;
+ private readonly IMediaSourceManager _mediaSourceManager;
+ private readonly IProcessFactory _processFactory;
+ private readonly ITextEncoding _textEncoding;
+
+ public SubtitleEncoder(ILibraryManager libraryManager, ILogger logger, IApplicationPaths appPaths, IFileSystem fileSystem, IMediaEncoder mediaEncoder, IJsonSerializer json, IHttpClient httpClient, IMediaSourceManager mediaSourceManager, IProcessFactory processFactory, ITextEncoding textEncoding)
+ {
+ _libraryManager = libraryManager;
+ _logger = logger;
+ _appPaths = appPaths;
+ _fileSystem = fileSystem;
+ _mediaEncoder = mediaEncoder;
+ _json = json;
+ _httpClient = httpClient;
+ _processFactory = processFactory;
+ _textEncoding = textEncoding;
+ }
+
+ private string SubtitleCachePath
+ {
+ get
+ {
+ return Path.Combine(_appPaths.DataPath, "subtitles");
+ }
+ }
+
+ private Stream ConvertSubtitles(Stream stream,
+ string inputFormat,
+ string outputFormat,
+ long startTimeTicks,
+ long? endTimeTicks,
+ bool preserveOriginalTimestamps,
+ CancellationToken cancellationToken)
+ {
+ var ms = new MemoryStream();
+
+ try
+ {
+ var reader = GetReader(inputFormat, true);
+
+ var trackInfo = reader.Parse(stream, cancellationToken);
+
+ FilterEvents(trackInfo, startTimeTicks, endTimeTicks, preserveOriginalTimestamps);
+
+ var writer = GetWriter(outputFormat);
+
+ writer.Write(trackInfo, ms, cancellationToken);
+ ms.Position = 0;
+ }
+ catch
+ {
+ ms.Dispose();
+ throw;
+ }
+
+ return ms;
+ }
+
+ private void FilterEvents(SubtitleTrackInfo track, long startPositionTicks, long? endTimeTicks, bool preserveTimestamps)
+ {
+ // Drop subs that are earlier than what we're looking for
+ track.TrackEvents = track.TrackEvents
+ .SkipWhile(i => (i.StartPositionTicks - startPositionTicks) < 0 || (i.EndPositionTicks - startPositionTicks) < 0)
+ .ToArray();
+
+ if (endTimeTicks.HasValue)
+ {
+ var endTime = endTimeTicks.Value;
+
+ track.TrackEvents = track.TrackEvents
+ .TakeWhile(i => i.StartPositionTicks <= endTime)
+ .ToArray();
+ }
+
+ if (!preserveTimestamps)
+ {
+ foreach (var trackEvent in track.TrackEvents)
+ {
+ trackEvent.EndPositionTicks -= startPositionTicks;
+ trackEvent.StartPositionTicks -= startPositionTicks;
+ }
+ }
+ }
+
+ async Task<Stream> ISubtitleEncoder.GetSubtitles(BaseItem item, string mediaSourceId, int subtitleStreamIndex, string outputFormat, long startTimeTicks, long endTimeTicks, bool preserveOriginalTimestamps, CancellationToken cancellationToken)
+ {
+ if (item == null)
+ {
+ throw new ArgumentNullException("item");
+ }
+ if (string.IsNullOrWhiteSpace(mediaSourceId))
+ {
+ throw new ArgumentNullException("mediaSourceId");
+ }
+
+ // TODO network path substition useful ?
+ var mediaSources = await _mediaSourceManager.GetPlayackMediaSources(item, null, true, true, cancellationToken).ConfigureAwait(false);
+
+ var mediaSource = mediaSources
+ .First(i => string.Equals(i.Id, mediaSourceId, StringComparison.OrdinalIgnoreCase));
+
+ var subtitleStream = mediaSource.MediaStreams
+ .First(i => i.Type == MediaStreamType.Subtitle && i.Index == subtitleStreamIndex);
+
+ var subtitle = await GetSubtitleStream(mediaSource, subtitleStream, cancellationToken)
+ .ConfigureAwait(false);
+
+ var inputFormat = subtitle.Item2;
+ var writer = TryGetWriter(outputFormat);
+
+ // Return the original if we don't have any way of converting it
+ if (writer == null)
+ {
+ return subtitle.Item1;
+ }
+
+ // Return the original if the same format is being requested
+ // Character encoding was already handled in GetSubtitleStream
+ if (string.Equals(inputFormat, outputFormat, StringComparison.OrdinalIgnoreCase))
+ {
+ return subtitle.Item1;
+ }
+
+ using (var stream = subtitle.Item1)
+ {
+ return ConvertSubtitles(stream, inputFormat, outputFormat, startTimeTicks, endTimeTicks, preserveOriginalTimestamps, cancellationToken);
+ }
+ }
+
+ private async Task<Tuple<Stream, string>> GetSubtitleStream(MediaSourceInfo mediaSource,
+ MediaStream subtitleStream,
+ CancellationToken cancellationToken)
+ {
+ var inputFiles = new[] { mediaSource.Path };
+
+ if (mediaSource.VideoType.HasValue)
+ {
+ if (mediaSource.VideoType.Value == VideoType.BluRay || mediaSource.VideoType.Value == VideoType.Dvd)
+ {
+ var mediaSourceItem = (Video)_libraryManager.GetItemById(new Guid(mediaSource.Id));
+ inputFiles = mediaSourceItem.GetPlayableStreamFileNames(_mediaEncoder).ToArray();
+ }
+ }
+
+ var fileInfo = await GetReadableFile(mediaSource.Path, inputFiles, mediaSource.Protocol, subtitleStream, cancellationToken).ConfigureAwait(false);
+
+ var stream = await GetSubtitleStream(fileInfo.Item1, subtitleStream.Language, fileInfo.Item2, fileInfo.Item4, cancellationToken).ConfigureAwait(false);
+
+ return new Tuple<Stream, string>(stream, fileInfo.Item3);
+ }
+
+ private async Task<Stream> GetSubtitleStream(string path, string language, MediaProtocol protocol, bool requiresCharset, CancellationToken cancellationToken)
+ {
+ if (requiresCharset)
+ {
+ var bytes = await GetBytes(path, protocol, cancellationToken).ConfigureAwait(false);
+
+ var charset = _textEncoding.GetDetectedEncodingName(bytes, bytes.Length, language, true);
+ _logger.Debug("charset {0} detected for {1}", charset ?? "null", path);
+
+ if (!string.IsNullOrEmpty(charset))
+ {
+ using (var inputStream = new MemoryStream(bytes))
+ {
+ using (var reader = new StreamReader(inputStream, _textEncoding.GetEncodingFromCharset(charset)))
+ {
+ var text = await reader.ReadToEndAsync().ConfigureAwait(false);
+
+ bytes = Encoding.UTF8.GetBytes(text);
+
+ return new MemoryStream(bytes);
+ }
+ }
+ }
+ }
+
+ return _fileSystem.OpenRead(path);
+ }
+
+ private async Task<Tuple<string, MediaProtocol, string, bool>> GetReadableFile(string mediaPath,
+ string[] inputFiles,
+ MediaProtocol protocol,
+ MediaStream subtitleStream,
+ CancellationToken cancellationToken)
+ {
+ if (!subtitleStream.IsExternal)
+ {
+ string outputFormat;
+ string outputCodec;
+
+ if (string.Equals(subtitleStream.Codec, "ass", StringComparison.OrdinalIgnoreCase) ||
+ string.Equals(subtitleStream.Codec, "ssa", StringComparison.OrdinalIgnoreCase) ||
+ string.Equals(subtitleStream.Codec, "srt", StringComparison.OrdinalIgnoreCase))
+ {
+ // Extract
+ outputCodec = "copy";
+ outputFormat = subtitleStream.Codec;
+ }
+ else if (string.Equals(subtitleStream.Codec, "subrip", StringComparison.OrdinalIgnoreCase))
+ {
+ // Extract
+ outputCodec = "copy";
+ outputFormat = "srt";
+ }
+ else
+ {
+ // Extract
+ outputCodec = "srt";
+ outputFormat = "srt";
+ }
+
+ // Extract
+ var outputPath = GetSubtitleCachePath(mediaPath, protocol, subtitleStream.Index, "." + outputFormat);
+
+ await ExtractTextSubtitle(inputFiles, protocol, subtitleStream.Index, outputCodec, outputPath, cancellationToken)
+ .ConfigureAwait(false);
+
+ return new Tuple<string, MediaProtocol, string, bool>(outputPath, MediaProtocol.File, outputFormat, false);
+ }
+
+ var currentFormat = (Path.GetExtension(subtitleStream.Path) ?? subtitleStream.Codec)
+ .TrimStart('.');
+
+ if (GetReader(currentFormat, false) == null)
+ {
+ // Convert
+ var outputPath = GetSubtitleCachePath(mediaPath, protocol, subtitleStream.Index, ".srt");
+
+ await ConvertTextSubtitleToSrt(subtitleStream.Path, subtitleStream.Language, protocol, outputPath, cancellationToken).ConfigureAwait(false);
+
+ return new Tuple<string, MediaProtocol, string, bool>(outputPath, MediaProtocol.File, "srt", true);
+ }
+
+ return new Tuple<string, MediaProtocol, string, bool>(subtitleStream.Path, protocol, currentFormat, true);
+ }
+
+ private ISubtitleParser GetReader(string format, bool throwIfMissing)
+ {
+ if (string.IsNullOrEmpty(format))
+ {
+ throw new ArgumentNullException("format");
+ }
+
+ if (string.Equals(format, SubtitleFormat.SRT, StringComparison.OrdinalIgnoreCase))
+ {
+ return new SrtParser(_logger);
+ }
+ if (string.Equals(format, SubtitleFormat.SSA, StringComparison.OrdinalIgnoreCase))
+ {
+ return new SsaParser();
+ }
+ if (string.Equals(format, SubtitleFormat.ASS, StringComparison.OrdinalIgnoreCase))
+ {
+ return new AssParser();
+ }
+
+ if (throwIfMissing)
+ {
+ throw new ArgumentException("Unsupported format: " + format);
+ }
+
+ return null;
+ }
+
+ private ISubtitleWriter TryGetWriter(string format)
+ {
+ if (string.IsNullOrEmpty(format))
+ {
+ throw new ArgumentNullException("format");
+ }
+
+ if (string.Equals(format, "json", StringComparison.OrdinalIgnoreCase))
+ {
+ return new JsonWriter(_json);
+ }
+ if (string.Equals(format, SubtitleFormat.SRT, StringComparison.OrdinalIgnoreCase))
+ {
+ return new SrtWriter();
+ }
+ if (string.Equals(format, SubtitleFormat.VTT, StringComparison.OrdinalIgnoreCase))
+ {
+ return new VttWriter();
+ }
+ if (string.Equals(format, SubtitleFormat.TTML, StringComparison.OrdinalIgnoreCase))
+ {
+ return new TtmlWriter();
+ }
+
+ return null;
+ }
+
+ private ISubtitleWriter GetWriter(string format)
+ {
+ var writer = TryGetWriter(format);
+
+ if (writer != null)
+ {
+ return writer;
+ }
+
+ throw new ArgumentException("Unsupported format: " + format);
+ }
+
+ /// <summary>
+ /// The _semaphoreLocks
+ /// </summary>
+ private readonly ConcurrentDictionary<string, SemaphoreSlim> _semaphoreLocks =
+ new ConcurrentDictionary<string, SemaphoreSlim>();
+
+ /// <summary>
+ /// Gets the lock.
+ /// </summary>
+ /// <param name="filename">The filename.</param>
+ /// <returns>System.Object.</returns>
+ private SemaphoreSlim GetLock(string filename)
+ {
+ return _semaphoreLocks.GetOrAdd(filename, key => new SemaphoreSlim(1, 1));
+ }
+
+ /// <summary>
+ /// Converts the text subtitle to SRT.
+ /// </summary>
+ /// <param name="inputPath">The input path.</param>
+ /// <param name="inputProtocol">The input protocol.</param>
+ /// <param name="outputPath">The output path.</param>
+ /// <param name="cancellationToken">The cancellation token.</param>
+ /// <returns>Task.</returns>
+ private async Task ConvertTextSubtitleToSrt(string inputPath, string language, MediaProtocol inputProtocol, string outputPath, CancellationToken cancellationToken)
+ {
+ var semaphore = GetLock(outputPath);
+
+ await semaphore.WaitAsync(cancellationToken).ConfigureAwait(false);
+
+ try
+ {
+ if (!_fileSystem.FileExists(outputPath))
+ {
+ await ConvertTextSubtitleToSrtInternal(inputPath, language, inputProtocol, outputPath, cancellationToken).ConfigureAwait(false);
+ }
+ }
+ finally
+ {
+ semaphore.Release();
+ }
+ }
+
+ /// <summary>
+ /// Converts the text subtitle to SRT internal.
+ /// </summary>
+ /// <param name="inputPath">The input path.</param>
+ /// <param name="inputProtocol">The input protocol.</param>
+ /// <param name="outputPath">The output path.</param>
+ /// <param name="cancellationToken">The cancellation token.</param>
+ /// <returns>Task.</returns>
+ /// <exception cref="System.ArgumentNullException">
+ /// inputPath
+ /// or
+ /// outputPath
+ /// </exception>
+ private async Task ConvertTextSubtitleToSrtInternal(string inputPath, string language, MediaProtocol inputProtocol, string outputPath, CancellationToken cancellationToken)
+ {
+ if (string.IsNullOrEmpty(inputPath))
+ {
+ throw new ArgumentNullException("inputPath");
+ }
+
+ if (string.IsNullOrEmpty(outputPath))
+ {
+ throw new ArgumentNullException("outputPath");
+ }
+
+ _fileSystem.CreateDirectory(_fileSystem.GetDirectoryName(outputPath));
+
+ var encodingParam = await GetSubtitleFileCharacterSet(inputPath, language, inputProtocol, cancellationToken).ConfigureAwait(false);
+
+ if (!string.IsNullOrEmpty(encodingParam))
+ {
+ encodingParam = " -sub_charenc " + encodingParam;
+ }
+
+ var process = _processFactory.Create(new ProcessOptions
+ {
+ CreateNoWindow = true,
+ UseShellExecute = false,
+ FileName = _mediaEncoder.EncoderPath,
+ Arguments = string.Format("{0} -i \"{1}\" -c:s srt \"{2}\"", encodingParam, inputPath, outputPath),
+
+ IsHidden = true,
+ ErrorDialog = false
+ });
+
+ _logger.Info("{0} {1}", process.StartInfo.FileName, process.StartInfo.Arguments);
+
+ try
+ {
+ process.Start();
+ }
+ catch (Exception ex)
+ {
+ _logger.ErrorException("Error starting ffmpeg", ex);
+
+ throw;
+ }
+
+ var ranToCompletion = await process.WaitForExitAsync(300000).ConfigureAwait(false);
+
+ if (!ranToCompletion)
+ {
+ try
+ {
+ _logger.Info("Killing ffmpeg subtitle conversion process");
+
+ process.Kill();
+ }
+ catch (Exception ex)
+ {
+ _logger.ErrorException("Error killing subtitle conversion process", ex);
+ }
+ }
+
+ var exitCode = ranToCompletion ? process.ExitCode : -1;
+
+ process.Dispose();
+
+ var failed = false;
+
+ if (exitCode == -1)
+ {
+ failed = true;
+
+ if (_fileSystem.FileExists(outputPath))
+ {
+ try
+ {
+ _logger.Info("Deleting converted subtitle due to failure: ", outputPath);
+ _fileSystem.DeleteFile(outputPath);
+ }
+ catch (IOException ex)
+ {
+ _logger.ErrorException("Error deleting converted subtitle {0}", ex, outputPath);
+ }
+ }
+ }
+ else if (!_fileSystem.FileExists(outputPath))
+ {
+ failed = true;
+ }
+
+ if (failed)
+ {
+ var msg = string.Format("ffmpeg subtitle conversion failed for {0}", inputPath);
+
+ _logger.Error(msg);
+
+ throw new Exception(msg);
+ }
+ await SetAssFont(outputPath).ConfigureAwait(false);
+
+ _logger.Info("ffmpeg subtitle conversion succeeded for {0}", inputPath);
+ }
+
+ /// <summary>
+ /// Extracts the text subtitle.
+ /// </summary>
+ /// <param name="inputFiles">The input files.</param>
+ /// <param name="protocol">The protocol.</param>
+ /// <param name="subtitleStreamIndex">Index of the subtitle stream.</param>
+ /// <param name="outputCodec">The output codec.</param>
+ /// <param name="outputPath">The output path.</param>
+ /// <param name="cancellationToken">The cancellation token.</param>
+ /// <returns>Task.</returns>
+ /// <exception cref="System.ArgumentException">Must use inputPath list overload</exception>
+ private async Task ExtractTextSubtitle(string[] inputFiles, MediaProtocol protocol, int subtitleStreamIndex,
+ string outputCodec, string outputPath, CancellationToken cancellationToken)
+ {
+ var semaphore = GetLock(outputPath);
+
+ await semaphore.WaitAsync(cancellationToken).ConfigureAwait(false);
+
+ try
+ {
+ if (!_fileSystem.FileExists(outputPath))
+ {
+ await ExtractTextSubtitleInternal(_mediaEncoder.GetInputArgument(inputFiles, protocol), subtitleStreamIndex, outputCodec, outputPath, cancellationToken).ConfigureAwait(false);
+ }
+ }
+ finally
+ {
+ semaphore.Release();
+ }
+ }
+
+ private async Task ExtractTextSubtitleInternal(string inputPath, int subtitleStreamIndex,
+ string outputCodec, string outputPath, CancellationToken cancellationToken)
+ {
+ if (string.IsNullOrEmpty(inputPath))
+ {
+ throw new ArgumentNullException("inputPath");
+ }
+
+ if (string.IsNullOrEmpty(outputPath))
+ {
+ throw new ArgumentNullException("outputPath");
+ }
+
+ _fileSystem.CreateDirectory(_fileSystem.GetDirectoryName(outputPath));
+
+ var processArgs = string.Format("-i {0} -map 0:{1} -an -vn -c:s {2} \"{3}\"", inputPath,
+ subtitleStreamIndex, outputCodec, outputPath);
+
+ var process = _processFactory.Create(new ProcessOptions
+ {
+ CreateNoWindow = true,
+ UseShellExecute = false,
+
+ FileName = _mediaEncoder.EncoderPath,
+ Arguments = processArgs,
+ IsHidden = true,
+ ErrorDialog = false
+ });
+
+ _logger.Info("{0} {1}", process.StartInfo.FileName, process.StartInfo.Arguments);
+
+ try
+ {
+ process.Start();
+ }
+ catch (Exception ex)
+ {
+ _logger.ErrorException("Error starting ffmpeg", ex);
+
+ throw;
+ }
+
+ var ranToCompletion = await process.WaitForExitAsync(300000).ConfigureAwait(false);
+
+ if (!ranToCompletion)
+ {
+ try
+ {
+ _logger.Info("Killing ffmpeg subtitle extraction process");
+
+ process.Kill();
+ }
+ catch (Exception ex)
+ {
+ _logger.ErrorException("Error killing subtitle extraction process", ex);
+ }
+ }
+
+ var exitCode = ranToCompletion ? process.ExitCode : -1;
+
+ process.Dispose();
+
+ var failed = false;
+
+ if (exitCode == -1)
+ {
+ failed = true;
+
+ try
+ {
+ _logger.Info("Deleting extracted subtitle due to failure: {0}", outputPath);
+ _fileSystem.DeleteFile(outputPath);
+ }
+ catch (FileNotFoundException)
+ {
+
+ }
+ catch (IOException ex)
+ {
+ _logger.ErrorException("Error deleting extracted subtitle {0}", ex, outputPath);
+ }
+ }
+ else if (!_fileSystem.FileExists(outputPath))
+ {
+ failed = true;
+ }
+
+ if (failed)
+ {
+ var msg = string.Format("ffmpeg subtitle extraction failed for {0} to {1}", inputPath, outputPath);
+
+ _logger.Error(msg);
+
+ throw new Exception(msg);
+ }
+ else
+ {
+ var msg = string.Format("ffmpeg subtitle extraction completed for {0} to {1}", inputPath, outputPath);
+
+ _logger.Info(msg);
+ }
+
+ if (string.Equals(outputCodec, "ass", StringComparison.OrdinalIgnoreCase))
+ {
+ await SetAssFont(outputPath).ConfigureAwait(false);
+ }
+ }
+
+ /// <summary>
+ /// Sets the ass font.
+ /// </summary>
+ /// <param name="file">The file.</param>
+ /// <returns>Task.</returns>
+ private async Task SetAssFont(string file)
+ {
+ _logger.Info("Setting ass font within {0}", file);
+
+ string text;
+ Encoding encoding;
+
+ using (var fileStream = _fileSystem.OpenRead(file))
+ {
+ using (var reader = new StreamReader(fileStream, true))
+ {
+ encoding = reader.CurrentEncoding;
+
+ text = await reader.ReadToEndAsync().ConfigureAwait(false);
+ }
+ }
+
+ var newText = text.Replace(",Arial,", ",Arial Unicode MS,");
+
+ if (!string.Equals(text, newText))
+ {
+ using (var fileStream = _fileSystem.GetFileStream(file, FileOpenMode.Create, FileAccessMode.Write, FileShareMode.Read))
+ {
+ using (var writer = new StreamWriter(fileStream, encoding))
+ {
+ writer.Write(newText);
+ }
+ }
+ }
+ }
+
+ private string GetSubtitleCachePath(string mediaPath, MediaProtocol protocol, int subtitleStreamIndex, string outputSubtitleExtension)
+ {
+ if (protocol == MediaProtocol.File)
+ {
+ var ticksParam = string.Empty;
+
+ var date = _fileSystem.GetLastWriteTimeUtc(mediaPath);
+
+ var filename = (mediaPath + "_" + subtitleStreamIndex.ToString(CultureInfo.InvariantCulture) + "_" + date.Ticks.ToString(CultureInfo.InvariantCulture) + ticksParam).GetMD5() + outputSubtitleExtension;
+
+ var prefix = filename.Substring(0, 1);
+
+ return Path.Combine(SubtitleCachePath, prefix, filename);
+ }
+ else
+ {
+ var filename = (mediaPath + "_" + subtitleStreamIndex.ToString(CultureInfo.InvariantCulture)).GetMD5() + outputSubtitleExtension;
+
+ var prefix = filename.Substring(0, 1);
+
+ return Path.Combine(SubtitleCachePath, prefix, filename);
+ }
+ }
+
+ public async Task<string> GetSubtitleFileCharacterSet(string path, string language, MediaProtocol protocol, CancellationToken cancellationToken)
+ {
+ var bytes = await GetBytes(path, protocol, cancellationToken).ConfigureAwait(false);
+
+ var charset = _textEncoding.GetDetectedEncodingName(bytes, bytes.Length, language, true);
+
+ _logger.Debug("charset {0} detected for {1}", charset ?? "null", path);
+
+ return charset;
+ }
+
+ private async Task<byte[]> GetBytes(string path, MediaProtocol protocol, CancellationToken cancellationToken)
+ {
+ if (protocol == MediaProtocol.Http)
+ {
+ HttpRequestOptions opts = new HttpRequestOptions();
+ opts.Url = path;
+ opts.CancellationToken = cancellationToken;
+ using (var file = await _httpClient.Get(opts).ConfigureAwait(false))
+ {
+ using (var memoryStream = new MemoryStream())
+ {
+ await file.CopyToAsync(memoryStream).ConfigureAwait(false);
+ memoryStream.Position = 0;
+
+ return memoryStream.ToArray();
+ }
+ }
+ }
+ if (protocol == MediaProtocol.File)
+ {
+ return _fileSystem.ReadAllBytes(path);
+ }
+
+ throw new ArgumentOutOfRangeException("protocol");
+ }
+
+ }
+} \ No newline at end of file