New: Use ASP.NET Core instead of Nancy

This commit is contained in:
ta264 2021-10-21 21:04:19 +01:00 committed by Qstick
parent c14ef7bee7
commit 2d53ec24f8
160 changed files with 2866 additions and 3657 deletions

View File

@ -78,7 +78,9 @@ export default {
const promise = createAjaxRequest({
method: 'PUT',
url: '/qualityDefinition/update',
data: JSON.stringify(upatedDefinitions)
data: JSON.stringify(upatedDefinitions),
contentType: 'application/json',
dataType: 'json'
}).request;
promise.done((data) => {

View File

@ -123,6 +123,7 @@ export const actionHandlers = handleThunks({
const promise = createAjaxRequest({
url: '/movie',
method: 'POST',
dataType: 'json',
contentType: 'application/json',
data: JSON.stringify(newMovie)
}).request;

View File

@ -160,6 +160,7 @@ export const actionHandlers = handleThunks({
url: '/blocklist/bulk',
method: 'DELETE',
dataType: 'json',
contentType: 'application/json',
data: JSON.stringify({ ids })
}).request;

View File

@ -139,7 +139,8 @@ export function executeCommandHelper( payload, dispatch) {
const promise = createAjaxRequest({
url: '/command',
method: 'POST',
data: JSON.stringify(payload)
data: JSON.stringify(payload),
dataType: 'json'
}).request;
return promise.then((data) => {

View File

@ -78,7 +78,8 @@ export const actionHandlers = handleThunks({
const promise = createAjaxRequest({
url: `/history/failed/${historyId}`,
method: 'POST'
method: 'POST',
dataType: 'json'
}).request;
promise.done(() => {
@ -97,4 +98,3 @@ export const reducers = createHandleActions({
}
}, defaultState, section);

View File

@ -396,6 +396,7 @@ export const actionHandlers = handleThunks({
url: `/queue/bulk?removeFromClient=${remove}&blocklist=${blocklist}`,
method: 'DELETE',
dataType: 'json',
contentType: 'application/json',
data: JSON.stringify({ ids })
}).request;
@ -453,4 +454,3 @@ export const reducers = createHandleActions({
})
}, defaultState, section);

View File

@ -240,6 +240,7 @@ export const actionHandlers = handleThunks({
const promise = createAjaxRequest({
url: '/release',
method: 'POST',
dataType: 'json',
contentType: 'application/json',
data: JSON.stringify(payload)
}).request;

View File

@ -53,7 +53,8 @@ export const actionHandlers = handleThunks({
const promise = createAjaxRequest({
url: '/tag',
method: 'POST',
data: JSON.stringify(payload.tag)
data: JSON.stringify(payload.tag),
dataType: 'json'
}).request;
promise.done((data) => {

View File

@ -7,18 +7,6 @@ function isRelative(ajaxOptions) {
return !absUrlRegex.test(ajaxOptions.url);
}
function moveBodyToQuery(ajaxOptions) {
if (ajaxOptions.data && ajaxOptions.type === 'DELETE') {
if (ajaxOptions.url.contains('?')) {
ajaxOptions.url += '&';
} else {
ajaxOptions.url += '?';
}
ajaxOptions.url += $.param(ajaxOptions.data);
delete ajaxOptions.data;
}
}
function addRootUrl(ajaxOptions) {
ajaxOptions.url = apiRoot + ajaxOptions.url;
}
@ -32,7 +20,7 @@ function addContentType(ajaxOptions) {
if (
ajaxOptions.contentType == null &&
ajaxOptions.dataType === 'json' &&
(ajaxOptions.method === 'PUT' || ajaxOptions.method === 'POST')) {
(ajaxOptions.method === 'PUT' || ajaxOptions.method === 'POST' || ajaxOptions.method === 'DELETE')) {
ajaxOptions.contentType = 'application/json';
}
}
@ -49,10 +37,9 @@ export default function createAjaxRequest(originalAjaxOptions) {
}
}
const ajaxOptions = { dataType: 'json', ...originalAjaxOptions };
const ajaxOptions = { ...originalAjaxOptions };
if (isRelative(ajaxOptions)) {
moveBodyToQuery(ajaxOptions);
addRootUrl(ajaxOptions);
addApiKey(ajaxOptions);
addContentType(ajaxOptions);

View File

@ -2,6 +2,7 @@ using System;
using System.IO;
using System.Text.Json;
using System.Text.Json.Serialization;
using System.Threading.Tasks;
namespace NzbDrone.Common.Serializer
{
@ -15,23 +16,25 @@ namespace NzbDrone.Common.Serializer
public static JsonSerializerOptions GetSerializerSettings()
{
var serializerSettings = new JsonSerializerOptions
{
AllowTrailingCommas = true,
DefaultIgnoreCondition = JsonIgnoreCondition.WhenWritingNull,
PropertyNameCaseInsensitive = true,
DictionaryKeyPolicy = JsonNamingPolicy.CamelCase,
PropertyNamingPolicy = JsonNamingPolicy.CamelCase,
WriteIndented = true
};
var settings = new JsonSerializerOptions();
ApplySerializerSettings(settings);
return settings;
}
public static void ApplySerializerSettings(JsonSerializerOptions serializerSettings)
{
serializerSettings.AllowTrailingCommas = true;
serializerSettings.DefaultIgnoreCondition = JsonIgnoreCondition.WhenWritingNull;
serializerSettings.PropertyNameCaseInsensitive = true;
serializerSettings.DictionaryKeyPolicy = JsonNamingPolicy.CamelCase;
serializerSettings.PropertyNamingPolicy = JsonNamingPolicy.CamelCase;
serializerSettings.WriteIndented = true;
serializerSettings.Converters.Add(new JsonStringEnumConverter(JsonNamingPolicy.CamelCase, true));
serializerSettings.Converters.Add(new STJVersionConverter());
serializerSettings.Converters.Add(new STJHttpUriConverter());
serializerSettings.Converters.Add(new STJTimeSpanConverter());
serializerSettings.Converters.Add(new STJUtcConverter());
return serializerSettings;
}
public static T Deserialize<T>(string json)
@ -84,5 +87,15 @@ namespace NzbDrone.Common.Serializer
JsonSerializer.Serialize(writer, (object)model, options);
}
}
public static Task SerializeAsync<TModel>(TModel model, Stream outputStream, JsonSerializerOptions options = null)
{
if (options == null)
{
options = SerializerSettings;
}
return JsonSerializer.SerializeAsync(outputStream, (object)model, options);
}
}
}

View File

@ -1,5 +1,4 @@
using System.Collections.Generic;
using Nancy.Bootstrapper;
using NzbDrone.Common.Composition;
using NzbDrone.Common.EnvironmentInfo;
using NzbDrone.SignalR;
@ -28,8 +27,6 @@ namespace Radarr.Host
{
AutoRegisterImplementations<MessageHub>();
Container.Register<INancyBootstrapper, RadarrBootstrapper>();
if (OsInfo.IsWindows)
{
Container.Register<INzbDroneServiceFactory, NzbDroneServiceFactory>();

View File

@ -0,0 +1,26 @@
using Microsoft.AspNetCore.Mvc;
using Microsoft.AspNetCore.Mvc.Controllers;
using NzbDrone.Common.Composition;
namespace NzbDrone.Host
{
public class ControllerActivator : IControllerActivator
{
private readonly IContainer _container;
public ControllerActivator(IContainer container)
{
_container = container;
}
public object Create(ControllerContext context)
{
return _container.Resolve(context.ActionDescriptor.ControllerTypeInfo.AsType());
}
public void Release(ControllerContext context, object controller)
{
// Nothing to do
}
}
}

View File

@ -1,10 +0,0 @@
using Microsoft.AspNetCore.Builder;
namespace Radarr.Host.Middleware
{
public interface IAspNetCoreMiddleware
{
int Order { get; }
void Attach(IApplicationBuilder appBuilder);
}
}

View File

@ -1,29 +0,0 @@
using Microsoft.AspNetCore.Builder;
using Nancy.Bootstrapper;
using Nancy.Owin;
namespace Radarr.Host.Middleware
{
public class NancyMiddleware : IAspNetCoreMiddleware
{
private readonly INancyBootstrapper _nancyBootstrapper;
public int Order => 2;
public NancyMiddleware(INancyBootstrapper nancyBootstrapper)
{
_nancyBootstrapper = nancyBootstrapper;
}
public void Attach(IApplicationBuilder appBuilder)
{
var options = new NancyOptions
{
Bootstrapper = _nancyBootstrapper,
PerformPassThrough = context => context.Request.Path.StartsWith("/signalr")
};
appBuilder.UseOwin(x => x.UseNancy(options));
}
}
}

View File

@ -1,72 +0,0 @@
using System;
using Microsoft.AspNetCore.Builder;
using Microsoft.AspNetCore.Http;
using Microsoft.AspNetCore.SignalR;
using Microsoft.Extensions.DependencyInjection;
using NLog;
using NzbDrone.Common.Composition;
using NzbDrone.Core.Configuration;
using NzbDrone.SignalR;
namespace Radarr.Host.Middleware
{
public class SignalRMiddleware : IAspNetCoreMiddleware
{
private readonly IContainer _container;
private readonly Logger _logger;
private static string API_KEY;
private static string URL_BASE;
public int Order => 1;
public SignalRMiddleware(IContainer container,
IConfigFileProvider configFileProvider,
Logger logger)
{
_container = container;
_logger = logger;
API_KEY = configFileProvider.ApiKey;
URL_BASE = configFileProvider.UrlBase;
}
public void Attach(IApplicationBuilder appBuilder)
{
appBuilder.UseWebSockets();
appBuilder.Use(async (context, next) =>
{
if (context.Request.Path.StartsWithSegments("/signalr") &&
!context.Request.Path.Value.EndsWith("/negotiate"))
{
if (!context.Request.Query.ContainsKey("access_token") ||
context.Request.Query["access_token"] != API_KEY)
{
context.Response.StatusCode = 401;
await context.Response.WriteAsync("Unauthorized");
return;
}
}
try
{
await next();
}
catch (OperationCanceledException e)
{
// Demote the exception to trace logging so users don't worry (as much).
_logger.Trace(e);
}
});
appBuilder.UseEndpoints(x =>
{
x.MapHub<MessageHub>(URL_BASE + "/signalr/messages");
});
// This is a side effect of haing multiple IoC containers, TinyIoC and whatever
// Kestrel/SignalR is using. Ideally we'd have one IoC container, but that's non-trivial with TinyIoC
// TODO: Use a single IoC container if supported for TinyIoC or if we switch to another system (ie Autofac).
var hubContext = appBuilder.ApplicationServices.GetService<IHubContext<MessageHub>>();
_container.Register(hubContext);
}
}
}

View File

@ -1,45 +1,62 @@
using System;
using System.Collections.Generic;
using System.IO;
using System.Linq;
using System.Security.Cryptography;
using System.Security.Cryptography.X509Certificates;
using Microsoft.AspNetCore.Authorization;
using Microsoft.AspNetCore.Builder;
using Microsoft.AspNetCore.Hosting;
using Microsoft.AspNetCore.Http;
using Microsoft.AspNetCore.Mvc.Controllers;
using Microsoft.AspNetCore.Mvc.Infrastructure;
using Microsoft.AspNetCore.Routing;
using Microsoft.AspNetCore.Routing.Internal;
using Microsoft.AspNetCore.SignalR;
using Microsoft.Extensions.DependencyInjection;
using Microsoft.Extensions.Logging;
using NLog;
using NLog.Extensions.Logging;
using NzbDrone.Common.Composition;
using NzbDrone.Common.EnvironmentInfo;
using NzbDrone.Common.Exceptions;
using NzbDrone.Common.Extensions;
using NzbDrone.Common.Serializer;
using NzbDrone.Core.Configuration;
using NzbDrone.Host;
using NzbDrone.SignalR;
using Radarr.Api.V3.System;
using Radarr.Host.AccessControl;
using Radarr.Host.Middleware;
using Radarr.Http;
using Radarr.Http.Authentication;
using Radarr.Http.ErrorManagement;
using Radarr.Http.Frontend;
using Radarr.Http.Middleware;
using LogLevel = Microsoft.Extensions.Logging.LogLevel;
namespace Radarr.Host
{
public class WebHostController : IHostController
{
private readonly IContainer _container;
private readonly IRuntimeInfo _runtimeInfo;
private readonly IConfigFileProvider _configFileProvider;
private readonly IFirewallAdapter _firewallAdapter;
private readonly IEnumerable<IAspNetCoreMiddleware> _middlewares;
private readonly RadarrErrorPipeline _errorHandler;
private readonly Logger _logger;
private IWebHost _host;
public WebHostController(IRuntimeInfo runtimeInfo,
public WebHostController(IContainer container,
IRuntimeInfo runtimeInfo,
IConfigFileProvider configFileProvider,
IFirewallAdapter firewallAdapter,
IEnumerable<IAspNetCoreMiddleware> middlewares,
RadarrErrorPipeline errorHandler,
Logger logger)
{
_container = container;
_runtimeInfo = runtimeInfo;
_configFileProvider = configFileProvider;
_firewallAdapter = firewallAdapter;
_middlewares = middlewares;
_errorHandler = errorHandler;
_logger = logger;
}
@ -106,24 +123,125 @@ namespace Radarr.Host
})
.ConfigureServices(services =>
{
// So that we can resolve containers with our TinyIoC services
services.AddSingleton(_container);
services.AddSingleton<IControllerActivator, ControllerActivator>();
// Bits used in our custom middleware
services.AddSingleton(_container.Resolve<RadarrErrorPipeline>());
services.AddSingleton(_container.Resolve<ICacheableSpecification>());
// Used in authentication
services.AddSingleton(_container.Resolve<IAuthenticationService>());
services.AddRouting(options => options.LowercaseUrls = true);
services.AddResponseCompression();
services.AddCors(options =>
{
options.AddPolicy(VersionedApiControllerAttribute.API_CORS_POLICY,
builder =>
builder.AllowAnyOrigin()
.AllowAnyMethod()
.AllowAnyHeader());
options.AddPolicy("AllowGet",
builder =>
builder.AllowAnyOrigin()
.WithMethods("GET", "OPTIONS")
.AllowAnyHeader());
});
services
.AddControllers(options =>
{
options.ReturnHttpNotAcceptable = true;
})
.AddApplicationPart(typeof(SystemController).Assembly)
.AddApplicationPart(typeof(StaticResourceController).Assembly)
.AddJsonOptions(options =>
{
STJson.ApplySerializerSettings(options.JsonSerializerOptions);
});
services
.AddSignalR()
.AddJsonProtocol(options =>
{
options.PayloadSerializerOptions = STJson.GetSerializerSettings();
});
services.AddAuthorization(options =>
{
options.AddPolicy("UI", policy =>
{
policy.AuthenticationSchemes.Add(_configFileProvider.AuthenticationMethod.ToString());
policy.RequireAuthenticatedUser();
});
options.AddPolicy("SignalR", policy =>
{
policy.AuthenticationSchemes.Add("SignalR");
policy.RequireAuthenticatedUser();
});
// Require auth on everything except those marked [AllowAnonymous]
options.DefaultPolicy = new AuthorizationPolicyBuilder("API")
.RequireAuthenticatedUser()
.Build();
});
services.AddAppAuthentication(_configFileProvider);
})
.Configure(app =>
{
app.UseRouting();
app.Properties["host.AppName"] = BuildInfo.AppName;
app.UsePathBase(_configFileProvider.UrlBase);
foreach (var middleWare in _middlewares.OrderBy(c => c.Order))
app.UseMiddleware<LoggingMiddleware>();
app.UsePathBase(new PathString(_configFileProvider.UrlBase));
app.UseExceptionHandler(new ExceptionHandlerOptions
{
_logger.Debug("Attaching {0} to host", middleWare.GetType().Name);
middleWare.Attach(app);
}
AllowStatusCode404Response = true,
ExceptionHandler = _errorHandler.HandleException
});
app.UseRouting();
app.UseCors();
app.UseAuthentication();
app.UseAuthorization();
app.UseResponseCompression();
app.Properties["host.AppName"] = BuildInfo.AppName;
app.UseMiddleware<VersionMiddleware>();
app.UseMiddleware<UrlBaseMiddleware>(_configFileProvider.UrlBase);
app.UseMiddleware<CacheHeaderMiddleware>();
app.UseMiddleware<IfModifiedMiddleware>();
app.Use((context, next) =>
{
if (context.Request.Path.StartsWithSegments("/api/v1/command", StringComparison.CurrentCultureIgnoreCase))
{
context.Request.EnableBuffering();
}
return next();
});
app.UseWebSockets();
app.UseEndpoints(x =>
{
x.MapHub<MessageHub>("/signalr/messages").RequireAuthorization("SignalR");
x.MapControllers();
});
// This is a side effect of haing multiple IoC containers, TinyIoC and whatever
// Kestrel/SignalR is using. Ideally we'd have one IoC container, but that's non-trivial with TinyIoC
// TODO: Use a single IoC container if supported for TinyIoC or if we switch to another system (ie Autofac).
_container.Register(app.ApplicationServices);
_container.Register(app.ApplicationServices.GetService<IHubContext<MessageHub>>());
_container.Register(app.ApplicationServices.GetService<IActionDescriptorCollectionProvider>());
_container.Register(app.ApplicationServices.GetService<EndpointDataSource>());
_container.Register(app.ApplicationServices.GetService<DfaGraphWriter>());
})
.UseContentRoot(Directory.GetCurrentDirectory())
.Build();

View File

@ -5,6 +5,7 @@ using NzbDrone.Integration.Test.Client;
namespace NzbDrone.Integration.Test.ApiTests
{
[TestFixture]
[Ignore("Not ready to be used on this branch")]
public class CommandFixture : IntegrationTest
{
[Test]

View File

@ -51,12 +51,7 @@ namespace NzbDrone.Integration.Test.Client
throw response.ErrorException;
}
var headers = response.Headers;
((string)headers.Single(c => c.Name == "Cache-Control").Value).Split(',').Select(x => x.Trim())
.Should().BeEquivalentTo("no-store, must-revalidate, no-cache, max-age=0".Split(',').Select(x => x.Trim()));
headers.Single(c => c.Name == "Pragma").Value.Should().Be("no-cache");
headers.Single(c => c.Name == "Expires").Value.Should().Be("0");
AssertDisableCache(response);
response.ErrorMessage.Should().BeNullOrWhiteSpace();
@ -72,6 +67,16 @@ namespace NzbDrone.Integration.Test.Client
return Json.Deserialize<T>(content);
}
private static void AssertDisableCache(IRestResponse response)
{
// cache control header gets reordered on net core
var headers = response.Headers;
((string)headers.Single(c => c.Name == "Cache-Control").Value).Split(',').Select(x => x.Trim())
.Should().BeEquivalentTo("no-store, no-cache".Split(',').Select(x => x.Trim()));
headers.Single(c => c.Name == "Pragma").Value.Should().Be("no-cache");
headers.Single(c => c.Name == "Expires").Value.Should().Be("-1");
}
}
public class ClientBase<TResource> : ClientBase

View File

@ -11,6 +11,7 @@ namespace NzbDrone.Integration.Test
private RestRequest BuildGet(string route = "movie")
{
var request = new RestRequest(route, Method.GET);
request.AddHeader("Origin", "http://a.different.domain");
request.AddHeader(AccessControlHeaders.RequestMethod, "POST");
return request;
@ -19,6 +20,8 @@ namespace NzbDrone.Integration.Test
private RestRequest BuildOptions(string route = "movie")
{
var request = new RestRequest(route, Method.OPTIONS);
request.AddHeader("Origin", "http://a.different.domain");
request.AddHeader(AccessControlHeaders.RequestMethod, "POST");
return request;
}

View File

@ -0,0 +1,55 @@
using System.Collections.Generic;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Blocklisting;
using NzbDrone.Core.CustomFormats;
using NzbDrone.Core.Datastore;
using Radarr.Http;
using Radarr.Http.Extensions;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.Blocklist
{
[V3ApiController]
public class BlocklistController : Controller
{
private readonly IBlocklistService _blocklistService;
private readonly ICustomFormatCalculationService _formatCalculator;
public BlocklistController(IBlocklistService blocklistService,
ICustomFormatCalculationService formatCalculator)
{
_blocklistService = blocklistService;
_formatCalculator = formatCalculator;
}
[HttpGet]
public PagingResource<BlocklistResource> GetBlocklist()
{
var pagingResource = Request.ReadPagingResourceFromRequest<BlocklistResource>();
var pagingSpec = pagingResource.MapToPagingSpec<BlocklistResource, NzbDrone.Core.Blocklisting.Blocklist>("date", SortDirection.Descending);
return pagingSpec.ApplyToPage(_blocklistService.Paged, model => BlocklistResourceMapper.MapToResource(model, _formatCalculator));
}
[HttpGet("movie")]
public List<BlocklistResource> GetMovieBlocklist(int movieId)
{
return _blocklistService.GetByMovieId(movieId).Select(h => BlocklistResourceMapper.MapToResource(h, _formatCalculator)).ToList();
}
[RestDeleteById]
public void DeleteBlocklist(int id)
{
_blocklistService.Delete(id);
}
[HttpDelete("bulk")]
public object Remove([FromBody] BlocklistBulkResource resource)
{
_blocklistService.Delete(resource.Ids);
return new object();
}
}
}

View File

@ -1,66 +0,0 @@
using System;
using System.Collections.Generic;
using System.Linq;
using NzbDrone.Core.Blocklisting;
using NzbDrone.Core.CustomFormats;
using NzbDrone.Core.Datastore;
using Radarr.Http;
using Radarr.Http.Extensions;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Blocklist
{
public class BlocklistModule : RadarrRestModule<BlocklistResource>
{
private readonly IBlocklistService _blocklistService;
private readonly ICustomFormatCalculationService _formatCalculator;
public BlocklistModule(IBlocklistService blocklistService,
ICustomFormatCalculationService formatCalculator)
{
_blocklistService = blocklistService;
_formatCalculator = formatCalculator;
GetResourcePaged = GetBlocklist;
DeleteResource = DeleteBlocklist;
Get("/movie", x => GetMovieBlocklist());
Delete("/bulk", x => Remove());
}
private PagingResource<BlocklistResource> GetBlocklist(PagingResource<BlocklistResource> pagingResource)
{
var pagingSpec = pagingResource.MapToPagingSpec<BlocklistResource, NzbDrone.Core.Blocklisting.Blocklist>("date", SortDirection.Descending);
return ApplyToPage(_blocklistService.Paged, pagingSpec, (blocklist) => BlocklistResourceMapper.MapToResource(blocklist, _formatCalculator));
}
private List<BlocklistResource> GetMovieBlocklist()
{
var queryMovieId = Request.Query.MovieId;
if (!queryMovieId.HasValue)
{
throw new BadRequestException("movieId is missing");
}
int movieId = Convert.ToInt32(queryMovieId.Value);
return _blocklistService.GetByMovieId(movieId).Select(h => BlocklistResourceMapper.MapToResource(h, _formatCalculator)).ToList();
}
private void DeleteBlocklist(int id)
{
_blocklistService.Delete(id);
}
private object Remove()
{
var resource = Request.Body.FromJson<BlocklistBulkResource>();
_blocklistService.Delete(resource.Ids);
return new object();
}
}
}

View File

@ -1,7 +1,7 @@
using System;
using System.Collections.Generic;
using System.Linq;
using Nancy;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Configuration;
using NzbDrone.Core.DecisionEngine.Specifications;
using NzbDrone.Core.Languages;
@ -10,57 +10,43 @@ using NzbDrone.Core.Movies.Translations;
using NzbDrone.SignalR;
using Radarr.Api.V3.Movies;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Calendar
{
public class CalendarModule : RadarrRestModuleWithSignalR<MovieResource, Movie>
[V3ApiController]
public class CalendarController : RestControllerWithSignalR<MovieResource, Movie>
{
private readonly IMovieService _moviesService;
private readonly IMovieTranslationService _movieTranslationService;
private readonly IUpgradableSpecification _qualityUpgradableSpecification;
private readonly IConfigService _configService;
public CalendarModule(IBroadcastSignalRMessage signalR,
public CalendarController(IBroadcastSignalRMessage signalR,
IMovieService moviesService,
IMovieTranslationService movieTranslationService,
IUpgradableSpecification qualityUpgradableSpecification,
IConfigService configService)
: base(signalR, "calendar")
: base(signalR)
{
_moviesService = moviesService;
_movieTranslationService = movieTranslationService;
_qualityUpgradableSpecification = qualityUpgradableSpecification;
_configService = configService;
GetResourceAll = GetCalendar;
}
private List<MovieResource> GetCalendar()
public override MovieResource GetResourceById(int id)
{
var start = DateTime.Today;
var end = DateTime.Today.AddDays(2);
var includeUnmonitored = false;
throw new NotImplementedException();
}
var queryStart = Request.Query.Start;
var queryEnd = Request.Query.End;
var queryIncludeUnmonitored = Request.Query.Unmonitored;
[HttpGet]
public List<MovieResource> GetCalendar(DateTime? start, DateTime? end, bool unmonitored = false, bool includeArtist = false)
{
var startUse = start ?? DateTime.Today;
var endUse = end ?? DateTime.Today.AddDays(2);
if (queryStart.HasValue)
{
start = DateTime.Parse(queryStart.Value);
}
if (queryEnd.HasValue)
{
end = DateTime.Parse(queryEnd.Value);
}
if (queryIncludeUnmonitored.HasValue)
{
includeUnmonitored = Convert.ToBoolean(queryIncludeUnmonitored.Value);
}
var resources = _moviesService.GetMoviesBetweenDates(start, end, includeUnmonitored).Select(MapToResource);
var resources = _moviesService.GetMoviesBetweenDates(startUse, endUse, unmonitored).Select(MapToResource);
return resources.OrderBy(e => e.InCinemas).ToList();
}

View File

@ -5,76 +5,36 @@ using Ical.Net;
using Ical.Net.CalendarComponents;
using Ical.Net.DataTypes;
using Ical.Net.Serialization;
using Nancy;
using Nancy.Responses;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Movies;
using NzbDrone.Core.Tags;
using Radarr.Http;
namespace Radarr.Api.V3.Calendar
{
public class CalendarFeedModule : RadarrV3FeedModule
[V3FeedController("calendar")]
public class CalendarFeedController : Controller
{
private readonly IMovieService _movieService;
private readonly ITagService _tagService;
public CalendarFeedModule(IMovieService movieService, ITagService tagService)
: base("calendar")
public CalendarFeedController(IMovieService movieService, ITagService tagService)
{
_movieService = movieService;
_tagService = tagService;
Get("/Radarr.ics", options => GetCalendarFeed());
}
private object GetCalendarFeed()
[HttpGet("Radarr.ics")]
public IActionResult GetCalendarFeed(int pastDays = 7, int futureDays = 28, string tagList = "", bool unmonitored = false)
{
var pastDays = 7;
var futureDays = 28;
var start = DateTime.Today.AddDays(-pastDays);
var end = DateTime.Today.AddDays(futureDays);
var unmonitored = false;
var tags = new List<int>();
// TODO: Remove start/end parameters in v3, they don't work well for iCal
var queryStart = Request.Query.Start;
var queryEnd = Request.Query.End;
var queryPastDays = Request.Query.PastDays;
var queryFutureDays = Request.Query.FutureDays;
var queryUnmonitored = Request.Query.Unmonitored;
var queryTags = Request.Query.Tags;
if (queryStart.HasValue)
if (tagList.IsNotNullOrWhiteSpace())
{
start = DateTime.Parse(queryStart.Value);
}
if (queryEnd.HasValue)
{
end = DateTime.Parse(queryEnd.Value);
}
if (queryPastDays.HasValue)
{
pastDays = int.Parse(queryPastDays.Value);
start = DateTime.Today.AddDays(-pastDays);
}
if (queryFutureDays.HasValue)
{
futureDays = int.Parse(queryFutureDays.Value);
end = DateTime.Today.AddDays(futureDays);
}
if (queryUnmonitored.HasValue)
{
unmonitored = bool.Parse(queryUnmonitored.Value);
}
if (queryTags.HasValue)
{
var tagInput = (string)queryTags.Value.ToString();
tags.AddRange(tagInput.Split(',').Select(_tagService.GetTag).Select(t => t.Id));
tags.AddRange(tagList.Split(',').Select(_tagService.GetTag).Select(t => t.Id));
}
var movies = _movieService.GetMoviesBetweenDates(start, end, unmonitored);
@ -102,7 +62,7 @@ namespace Radarr.Api.V3.Calendar
var serializer = (IStringSerializer)new SerializerFactory().Build(calendar.GetType(), new SerializationContext());
var icalendar = serializer.SerializeToString(calendar);
return new TextResponse(icalendar, "text/calendar");
return Content(icalendar, "text/calendar");
}
private void CreateEvent(Ical.Net.Calendar calendar, Movie movie, string releaseType)

View File

@ -1,7 +1,10 @@
using System;
using System.Collections.Generic;
using System.IO;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common;
using NzbDrone.Common.Serializer;
using NzbDrone.Common.TPL;
using NzbDrone.Core.Datastore.Events;
using NzbDrone.Core.Messaging.Commands;
@ -9,19 +12,21 @@ using NzbDrone.Core.Messaging.Events;
using NzbDrone.Core.ProgressMessaging;
using NzbDrone.SignalR;
using Radarr.Http;
using Radarr.Http.Extensions;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
using Radarr.Http.Validation;
namespace Radarr.Api.V3.Commands
{
public class CommandModule : RadarrRestModuleWithSignalR<CommandResource, CommandModel>, IHandle<CommandUpdatedEvent>
[V3ApiController]
public class CommandController : RestControllerWithSignalR<CommandResource, CommandModel>, IHandle<CommandUpdatedEvent>
{
private readonly IManageCommandQueue _commandQueueManager;
private readonly IServiceFactory _serviceFactory;
private readonly Debouncer _debouncer;
private readonly Dictionary<int, CommandResource> _pendingUpdates;
public CommandModule(IManageCommandQueue commandQueueManager,
public CommandController(IManageCommandQueue commandQueueManager,
IBroadcastSignalRMessage signalRBroadcaster,
IServiceFactory serviceFactory)
: base(signalRBroadcaster)
@ -32,47 +37,52 @@ namespace Radarr.Api.V3.Commands
_debouncer = new Debouncer(SendUpdates, TimeSpan.FromSeconds(0.1));
_pendingUpdates = new Dictionary<int, CommandResource>();
GetResourceById = GetCommand;
CreateResource = StartCommand;
GetResourceAll = GetStartedCommands;
DeleteResource = CancelCommand;
PostValidator.RuleFor(c => c.Name).NotBlank();
}
private CommandResource GetCommand(int id)
public override CommandResource GetResourceById(int id)
{
return _commandQueueManager.Get(id).ToResource();
}
private int StartCommand(CommandResource commandResource)
[RestPostById]
public ActionResult<CommandResource> StartCommand(CommandResource commandResource)
{
var commandType =
_serviceFactory.GetImplementations(typeof(Command))
.Single(c => c.Name.Replace("Command", "")
.Equals(commandResource.Name, StringComparison.InvariantCultureIgnoreCase));
dynamic command = Request.Body.FromJson(commandType);
command.Trigger = CommandTrigger.Manual;
command.SuppressMessages = !command.SendUpdatesToClient;
command.SendUpdatesToClient = true;
Request.Body.Seek(0, SeekOrigin.Begin);
using (var reader = new StreamReader(Request.Body))
{
var body = reader.ReadToEnd();
command.ClientUserAgent = Request.Headers.UserAgent;
dynamic command = STJson.Deserialize(body, commandType);
var trackedCommand = _commandQueueManager.Push(command, CommandPriority.Normal, CommandTrigger.Manual);
return trackedCommand.Id;
command.Trigger = CommandTrigger.Manual;
command.SuppressMessages = !command.SendUpdatesToClient;
command.SendUpdatesToClient = true;
command.ClientUserAgent = Request.Headers["UserAgent"];
var trackedCommand = _commandQueueManager.Push(command, CommandPriority.Normal, CommandTrigger.Manual);
return Created(trackedCommand.Id);
}
}
private List<CommandResource> GetStartedCommands()
[HttpGet]
public List<CommandResource> GetStartedCommands()
{
return _commandQueueManager.All().ToResource();
}
private void CancelCommand(int id)
[RestDeleteById]
public void CancelCommand(int id)
{
_commandQueueManager.Cancel(id);
}
[NonAction]
public void Handle(CommandUpdatedEvent message)
{
if (message.Command.Body.SendUpdatesToClient)

View File

@ -0,0 +1,48 @@
using System.Linq;
using System.Reflection;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Configuration;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.Config
{
public abstract class ConfigController<TResource> : RestController<TResource>
where TResource : RestResource, new()
{
private readonly IConfigService _configService;
protected ConfigController(IConfigService configService)
{
_configService = configService;
}
public override TResource GetResourceById(int id)
{
return GetConfig();
}
[HttpGet]
public TResource GetConfig()
{
var resource = ToResource(_configService);
resource.Id = 1;
return resource;
}
[RestPutById]
public ActionResult<TResource> SaveConfig(TResource resource)
{
var dictionary = resource.GetType()
.GetProperties(BindingFlags.Instance | BindingFlags.Public)
.ToDictionary(prop => prop.Name, prop => prop.GetValue(resource, null));
_configService.SaveConfigDictionary(dictionary);
return Accepted(resource.Id);
}
protected abstract TResource ToResource(IConfigService model);
}
}

View File

@ -1,10 +1,12 @@
using NzbDrone.Core.Configuration;
using Radarr.Http;
namespace Radarr.Api.V3.Config
{
public class DownloadClientConfigModule : RadarrConfigModule<DownloadClientConfigResource>
[V3ApiController("config/downloadclient")]
public class DownloadClientConfigController : ConfigController<DownloadClientConfigResource>
{
public DownloadClientConfigModule(IConfigService configService)
public DownloadClientConfigController(IConfigService configService)
: base(configService)
{
}

View File

@ -3,6 +3,7 @@ using System.Linq;
using System.Reflection;
using System.Security.Cryptography.X509Certificates;
using FluentValidation;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Authentication;
using NzbDrone.Core.Configuration;
@ -10,29 +11,27 @@ using NzbDrone.Core.Update;
using NzbDrone.Core.Validation;
using NzbDrone.Core.Validation.Paths;
using Radarr.Http;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.Config
{
public class HostConfigModule : RadarrRestModule<HostConfigResource>
[V3ApiController("config/host")]
public class HostConfigController : RestController<HostConfigResource>
{
private readonly IConfigFileProvider _configFileProvider;
private readonly IConfigService _configService;
private readonly IUserService _userService;
public HostConfigModule(IConfigFileProvider configFileProvider,
IConfigService configService,
IUserService userService,
FileExistsValidator fileExistsValidator)
: base("/config/host")
public HostConfigController(IConfigFileProvider configFileProvider,
IConfigService configService,
IUserService userService,
FileExistsValidator fileExistsValidator)
{
_configFileProvider = configFileProvider;
_configService = configService;
_userService = userService;
GetResourceSingle = GetHostConfig;
GetResourceById = GetHostConfig;
UpdateResource = SaveHostConfig;
SharedValidator.RuleFor(c => c.BindAddress)
.ValidIp4Address()
.NotListenAllIp4Address()
@ -79,7 +78,13 @@ namespace Radarr.Api.V3.Config
return cert != null;
}
private HostConfigResource GetHostConfig()
public override HostConfigResource GetResourceById(int id)
{
return GetHostConfig();
}
[HttpGet]
public HostConfigResource GetHostConfig()
{
var resource = _configFileProvider.ToResource(_configService);
resource.Id = 1;
@ -94,12 +99,8 @@ namespace Radarr.Api.V3.Config
return resource;
}
private HostConfigResource GetHostConfig(int id)
{
return GetHostConfig();
}
private void SaveHostConfig(HostConfigResource resource)
[RestPutById]
public ActionResult<HostConfigResource> SaveHostConfig(HostConfigResource resource)
{
var dictionary = resource.GetType()
.GetProperties(BindingFlags.Instance | BindingFlags.Public)
@ -112,6 +113,8 @@ namespace Radarr.Api.V3.Config
{
_userService.Upsert(resource.Username, resource.Password);
}
return Accepted(resource.Id);
}
}
}

View File

@ -1,11 +1,14 @@
using NzbDrone.Core.Configuration;
using Radarr.Http;
using Radarr.Http.Validation;
namespace Radarr.Api.V3.Config
{
public class ImportListConfigModule : RadarrConfigModule<ImportListConfigResource>
[V3ApiController("config/importlist")]
public class ImportListConfigController : ConfigController<ImportListConfigResource>
{
public ImportListConfigModule(IConfigService configService)
public ImportListConfigController(IConfigService configService)
: base(configService)
{
SharedValidator.RuleFor(c => c.ImportListSyncInterval)

View File

@ -1,12 +1,14 @@
using FluentValidation;
using NzbDrone.Core.Configuration;
using Radarr.Http;
using Radarr.Http.Validation;
namespace Radarr.Api.V3.Config
{
public class IndexerConfigModule : RadarrConfigModule<IndexerConfigResource>
[V3ApiController("config/indexer")]
public class IndexerConfigController : ConfigController<IndexerConfigResource>
{
public IndexerConfigModule(IConfigService configService)
public IndexerConfigController(IConfigService configService)
: base(configService)
{
SharedValidator.RuleFor(c => c.MinimumAge)

View File

@ -3,12 +3,14 @@ using NzbDrone.Common.EnvironmentInfo;
using NzbDrone.Core.Configuration;
using NzbDrone.Core.Validation;
using NzbDrone.Core.Validation.Paths;
using Radarr.Http;
namespace Radarr.Api.V3.Config
{
public class MediaManagementConfigModule : RadarrConfigModule<MediaManagementConfigResource>
[V3ApiController("config/mediamanagement")]
public class MediaManagementConfigController : ConfigController<MediaManagementConfigResource>
{
public MediaManagementConfigModule(IConfigService configService,
public MediaManagementConfigController(IConfigService configService,
PathExistsValidator pathExistsValidator,
FolderChmodValidator folderChmodValidator,
FolderWritableValidator folderWritableValidator,

View File

@ -1,10 +1,12 @@
using NzbDrone.Core.Configuration;
using Radarr.Http;
namespace Radarr.Api.V3.Config
{
public class MetadataConfigModule : RadarrConfigModule<MetadataConfigResource>
[V3ApiController("config/metadata")]
public class MetadataConfigController : ConfigController<MetadataConfigResource>
{
public MetadataConfigModule(IConfigService configService)
public MetadataConfigController(IConfigService configService)
: base(configService)
{
}

View File

@ -2,49 +2,44 @@ using System.Collections.Generic;
using System.Linq;
using FluentValidation;
using FluentValidation.Results;
using Nancy.ModelBinding;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Organizer;
using Radarr.Http;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.Config
{
public class NamingConfigModule : RadarrRestModule<NamingConfigResource>
[V3ApiController("config/naming")]
public class NamingConfigController : RestController<NamingConfigResource>
{
private readonly INamingConfigService _namingConfigService;
private readonly IFilenameSampleService _filenameSampleService;
private readonly IFilenameValidationService _filenameValidationService;
private readonly IBuildFileNames _filenameBuilder;
public NamingConfigModule(INamingConfigService namingConfigService,
IFilenameSampleService filenameSampleService,
IFilenameValidationService filenameValidationService,
IBuildFileNames filenameBuilder)
: base("config/naming")
public NamingConfigController(INamingConfigService namingConfigService,
IFilenameSampleService filenameSampleService,
IFilenameValidationService filenameValidationService,
IBuildFileNames filenameBuilder)
{
_namingConfigService = namingConfigService;
_filenameSampleService = filenameSampleService;
_filenameValidationService = filenameValidationService;
_filenameBuilder = filenameBuilder;
GetResourceSingle = GetNamingConfig;
GetResourceById = GetNamingConfig;
UpdateResource = UpdateNamingConfig;
Get("/examples", x => GetExamples(this.Bind<NamingConfigResource>()));
SharedValidator.RuleFor(c => c.StandardMovieFormat).ValidMovieFormat();
SharedValidator.RuleFor(c => c.MovieFolderFormat).ValidMovieFolderFormat();
}
private void UpdateNamingConfig(NamingConfigResource resource)
public override NamingConfigResource GetResourceById(int id)
{
var nameSpec = resource.ToModel();
ValidateFormatResult(nameSpec);
_namingConfigService.Save(nameSpec);
return GetNamingConfig();
}
private NamingConfigResource GetNamingConfig()
[HttpGet]
public NamingConfigResource GetNamingConfig()
{
var nameSpec = _namingConfigService.GetConfig();
var resource = nameSpec.ToResource();
@ -58,12 +53,19 @@ namespace Radarr.Api.V3.Config
return resource;
}
private NamingConfigResource GetNamingConfig(int id)
[RestPutById]
public ActionResult<NamingConfigResource> UpdateNamingConfig(NamingConfigResource resource)
{
return GetNamingConfig();
var nameSpec = resource.ToModel();
ValidateFormatResult(nameSpec);
_namingConfigService.Save(nameSpec);
return Accepted(resource.Id);
}
private object GetExamples(NamingConfigResource config)
[HttpGet("examples")]
public object GetExamples([FromQuery]NamingConfigResource config)
{
if (config.Id == 0)
{

View File

@ -1,53 +0,0 @@
using System.Linq;
using System.Reflection;
using NzbDrone.Core.Configuration;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Config
{
public abstract class RadarrConfigModule<TResource> : RadarrRestModule<TResource>
where TResource : RestResource, new()
{
private readonly IConfigService _configService;
protected RadarrConfigModule(IConfigService configService)
: this(new TResource().ResourceName.Replace("config", ""), configService)
{
}
protected RadarrConfigModule(string resource, IConfigService configService)
: base("config/" + resource.Trim('/'))
{
_configService = configService;
GetResourceSingle = GetConfig;
GetResourceById = GetConfig;
UpdateResource = SaveConfig;
}
private TResource GetConfig()
{
var resource = ToResource(_configService);
resource.Id = 1;
return resource;
}
protected abstract TResource ToResource(IConfigService model);
private TResource GetConfig(int id)
{
return GetConfig();
}
private void SaveConfig(TResource resource)
{
var dictionary = resource.GetType()
.GetProperties(BindingFlags.Instance | BindingFlags.Public)
.ToDictionary(prop => prop.Name, prop => prop.GetValue(resource, null));
_configService.SaveConfigDictionary(dictionary);
}
}
}

View File

@ -1,10 +1,12 @@
using NzbDrone.Core.Configuration;
using Radarr.Http;
namespace Radarr.Api.V3.Config
{
public class UiConfigModule : RadarrConfigModule<UiConfigResource>
[V3ApiController("config/ui")]
public class UiConfigController : ConfigController<UiConfigResource>
{
public UiConfigModule(IConfigService configService)
public UiConfigController(IConfigService configService)
: base(configService)
{
}

View File

@ -1,36 +1,32 @@
using System;
using System.Collections.Generic;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Movies.Credits;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Credits
{
public class CreditModule : RadarrRestModule<CreditResource>
[V3ApiController]
public class CreditController : RestController<CreditResource>
{
private readonly ICreditService _creditService;
public CreditModule(ICreditService creditService)
public CreditController(ICreditService creditService)
{
_creditService = creditService;
GetResourceById = GetCredit;
GetResourceAll = GetCredits;
}
private CreditResource GetCredit(int id)
public override CreditResource GetResourceById(int id)
{
return _creditService.GetById(id).ToResource();
}
private List<CreditResource> GetCredits()
[HttpGet]
public List<CreditResource> GetCredits(int? movieId)
{
var movieIdQuery = Request.Query.MovieId;
if (movieIdQuery.HasValue)
if (movieId.HasValue)
{
int movieId = Convert.ToInt32(movieIdQuery.Value);
return _creditService.GetAllCreditsForMovie(movieId).ToResource();
return _creditService.GetAllCreditsForMovie(movieId.Value).ToResource();
}
return _creditService.GetAllCredits().ToResource();

View File

@ -0,0 +1,52 @@
using System.Collections.Generic;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.CustomFilters;
using Radarr.Http;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.CustomFilters
{
[V3ApiController]
public class CustomFilterController : RestController<CustomFilterResource>
{
private readonly ICustomFilterService _customFilterService;
public CustomFilterController(ICustomFilterService customFilterService)
{
_customFilterService = customFilterService;
}
public override CustomFilterResource GetResourceById(int id)
{
return _customFilterService.Get(id).ToResource();
}
[HttpGet]
public List<CustomFilterResource> GetCustomFilters()
{
return _customFilterService.All().ToResource();
}
[RestPostById]
public ActionResult<CustomFilterResource> AddCustomFilter(CustomFilterResource resource)
{
var customFilter = _customFilterService.Add(resource.ToModel());
return Created(customFilter.Id);
}
[RestPutById]
public ActionResult<CustomFilterResource> UpdateCustomFilter(CustomFilterResource resource)
{
_customFilterService.Update(resource.ToModel());
return Accepted(resource.Id);
}
[RestDeleteById]
public void DeleteCustomResource(int id)
{
_customFilterService.Delete(id);
}
}
}

View File

@ -1,49 +0,0 @@
using System.Collections.Generic;
using NzbDrone.Core.CustomFilters;
using Radarr.Http;
namespace Radarr.Api.V3.CustomFilters
{
public class CustomFilterModule : RadarrRestModule<CustomFilterResource>
{
private readonly ICustomFilterService _customFilterService;
public CustomFilterModule(ICustomFilterService customFilterService)
{
_customFilterService = customFilterService;
GetResourceById = GetCustomFilter;
GetResourceAll = GetCustomFilters;
CreateResource = AddCustomFilter;
UpdateResource = UpdateCustomFilter;
DeleteResource = DeleteCustomResource;
}
private CustomFilterResource GetCustomFilter(int id)
{
return _customFilterService.Get(id).ToResource();
}
private List<CustomFilterResource> GetCustomFilters()
{
return _customFilterService.All().ToResource();
}
private int AddCustomFilter(CustomFilterResource resource)
{
var customFilter = _customFilterService.Add(resource.ToModel());
return customFilter.Id;
}
private void UpdateCustomFilter(CustomFilterResource resource)
{
_customFilterService.Update(resource.ToModel());
}
private void DeleteCustomResource(int id)
{
_customFilterService.Delete(id);
}
}
}

View File

@ -1,17 +1,21 @@
using System.Collections.Generic;
using System.Linq;
using FluentValidation;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.CustomFormats;
using Radarr.Http;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.CustomFormats
{
public class CustomFormatModule : RadarrRestModule<CustomFormatResource>
[V3ApiController]
public class CustomFormatController : RestController<CustomFormatResource>
{
private readonly ICustomFormatService _formatService;
private readonly List<ICustomFormatSpecification> _specifications;
public CustomFormatModule(ICustomFormatService formatService,
public CustomFormatController(ICustomFormatService formatService,
List<ICustomFormatSpecification> specifications)
{
_formatService = formatService;
@ -21,48 +25,43 @@ namespace Radarr.Api.V3.CustomFormats
SharedValidator.RuleFor(c => c.Name)
.Must((v, c) => !_formatService.All().Any(f => f.Name == c && f.Id != v.Id)).WithMessage("Must be unique.");
SharedValidator.RuleFor(c => c.Specifications).NotEmpty();
GetResourceAll = GetAll;
GetResourceById = GetById;
UpdateResource = Update;
CreateResource = Create;
DeleteResource = DeleteFormat;
Get("schema", x => GetTemplates());
}
private int Create(CustomFormatResource customFormatResource)
{
var model = customFormatResource.ToModel(_specifications);
return _formatService.Insert(model).Id;
}
private void Update(CustomFormatResource resource)
{
var model = resource.ToModel(_specifications);
_formatService.Update(model);
}
private CustomFormatResource GetById(int id)
public override CustomFormatResource GetResourceById(int id)
{
return _formatService.GetById(id).ToResource();
}
private List<CustomFormatResource> GetAll()
[RestPostById]
public ActionResult<CustomFormatResource> Create(CustomFormatResource customFormatResource)
{
var model = customFormatResource.ToModel(_specifications);
return Created(_formatService.Insert(model).Id);
}
[RestPutById]
public ActionResult<CustomFormatResource> Update(CustomFormatResource resource)
{
var model = resource.ToModel(_specifications);
_formatService.Update(model);
return Accepted(model.Id);
}
[HttpGet]
public List<CustomFormatResource> GetAll()
{
return _formatService.All().ToResource();
}
private void DeleteFormat(int id)
[RestDeleteById]
public void DeleteFormat(int id)
{
_formatService.Delete(id);
}
private object GetTemplates()
[HttpGet("schema")]
public object GetTemplates()
{
var schema = _specifications.OrderBy(x => x.Order).Select(x => x.ToSchema()).ToList();

View File

@ -1,20 +1,21 @@
using System.Collections.Generic;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.DiskSpace;
using Radarr.Http;
namespace Radarr.Api.V3.DiskSpace
{
public class DiskSpaceModule : RadarrRestModule<DiskSpaceResource>
[V3ApiController("diskspace")]
public class DiskSpaceController : Controller
{
private readonly IDiskSpaceService _diskSpaceService;
public DiskSpaceModule(IDiskSpaceService diskSpaceService)
: base("diskspace")
public DiskSpaceController(IDiskSpaceService diskSpaceService)
{
_diskSpaceService = diskSpaceService;
GetResourceAll = GetFreeSpace;
}
[HttpGet]
public List<DiskSpaceResource> GetFreeSpace()
{
return _diskSpaceService.GetFreeSpace().ConvertAll(DiskSpaceResourceMapper.MapToResource);

View File

@ -1,12 +1,14 @@
using NzbDrone.Core.Download;
using Radarr.Http;
namespace Radarr.Api.V3.DownloadClient
{
public class DownloadClientModule : ProviderModuleBase<DownloadClientResource, IDownloadClient, DownloadClientDefinition>
[V3ApiController]
public class DownloadClientController : ProviderControllerBase<DownloadClientResource, IDownloadClient, DownloadClientDefinition>
{
public static readonly DownloadClientResourceMapper ResourceMapper = new DownloadClientResourceMapper();
public DownloadClientModule(IDownloadClientFactory downloadClientFactory)
public DownloadClientController(IDownloadClientFactory downloadClientFactory)
: base(downloadClientFactory, "downloadclient", ResourceMapper)
{
}

View File

@ -1,40 +1,35 @@
using System.Collections.Generic;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Extras.Files;
using NzbDrone.Core.Extras.Metadata.Files;
using NzbDrone.Core.Extras.Others;
using NzbDrone.Core.Extras.Subtitles;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.ExtraFiles
{
public class ExtraFileModule : RadarrRestModule<ExtraFileResource>
[V3ApiController("extrafile")]
public class ExtraFileController : Controller
{
private readonly IExtraFileService<SubtitleFile> _subtitleFileService;
private readonly IExtraFileService<MetadataFile> _metadataFileService;
private readonly IExtraFileService<OtherExtraFile> _otherFileService;
public ExtraFileModule(IExtraFileService<SubtitleFile> subtitleFileService, IExtraFileService<MetadataFile> metadataFileService, IExtraFileService<OtherExtraFile> otherExtraFileService)
: base("/extrafile")
public ExtraFileController(IExtraFileService<SubtitleFile> subtitleFileService, IExtraFileService<MetadataFile> metadataFileService, IExtraFileService<OtherExtraFile> otherExtraFileService)
{
_subtitleFileService = subtitleFileService;
_metadataFileService = metadataFileService;
_otherFileService = otherExtraFileService;
GetResourceAll = GetFiles;
}
private List<ExtraFileResource> GetFiles()
[HttpGet]
public List<ExtraFileResource> GetFiles(int movieId)
{
if (!Request.Query.MovieId.HasValue)
{
throw new BadRequestException("MovieId is missing");
}
var extraFiles = new List<ExtraFileResource>();
List<SubtitleFile> subtitleFiles = _subtitleFileService.GetFilesByMovie(Request.Query.MovieId);
List<MetadataFile> metadataFiles = _metadataFileService.GetFilesByMovie(Request.Query.MovieId);
List<OtherExtraFile> otherExtraFiles = _otherFileService.GetFilesByMovie(Request.Query.MovieId);
List<SubtitleFile> subtitleFiles = _subtitleFileService.GetFilesByMovie(movieId);
List<MetadataFile> metadataFiles = _metadataFileService.GetFilesByMovie(movieId);
List<OtherExtraFile> otherExtraFiles = _otherFileService.GetFilesByMovie(movieId);
extraFiles.AddRange(subtitleFiles.ToResource());
extraFiles.AddRange(metadataFiles.ToResource());

View File

@ -1,47 +1,39 @@
using System;
using System.IO;
using System.Linq;
using Nancy;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Disk;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.MediaFiles;
using Radarr.Http.Extensions;
using Radarr.Http;
namespace Radarr.Api.V3.FileSystem
{
public class FileSystemModule : RadarrV3Module
[V3ApiController]
public class FileSystemController : Controller
{
private readonly IFileSystemLookupService _fileSystemLookupService;
private readonly IDiskProvider _diskProvider;
private readonly IDiskScanService _diskScanService;
public FileSystemModule(IFileSystemLookupService fileSystemLookupService,
public FileSystemController(IFileSystemLookupService fileSystemLookupService,
IDiskProvider diskProvider,
IDiskScanService diskScanService)
: base("/filesystem")
{
_fileSystemLookupService = fileSystemLookupService;
_diskProvider = diskProvider;
_diskScanService = diskScanService;
Get("/", x => GetContents());
Get("/type", x => GetEntityType());
Get("/mediafiles", x => GetMediaFiles());
}
private object GetContents()
[HttpGet]
public IActionResult GetContents(string path, bool includeFiles = false, bool allowFoldersWithoutTrailingSlashes = false)
{
var pathQuery = Request.Query.path;
var includeFiles = Request.GetBooleanQueryParameter("includeFiles");
var allowFoldersWithoutTrailingSlashes = Request.GetBooleanQueryParameter("allowFoldersWithoutTrailingSlashes");
return _fileSystemLookupService.LookupContents((string)pathQuery.Value, includeFiles, allowFoldersWithoutTrailingSlashes);
return Ok(_fileSystemLookupService.LookupContents(path, includeFiles, allowFoldersWithoutTrailingSlashes));
}
private object GetEntityType()
[HttpGet("type")]
public object GetEntityType(string path)
{
var pathQuery = Request.Query.path;
var path = (string)pathQuery.Value;
if (_diskProvider.FileExists(path))
{
return new { type = "file" };
@ -51,11 +43,9 @@ namespace Radarr.Api.V3.FileSystem
return new { type = "folder" };
}
private object GetMediaFiles()
[HttpGet("mediafiles")]
public object GetMediaFiles(string path)
{
var pathQuery = Request.Query.path;
var path = (string)pathQuery.Value;
if (!_diskProvider.FolderExists(path))
{
return Array.Empty<string>();

View File

@ -1,29 +1,39 @@
using System;
using System.Collections.Generic;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Datastore.Events;
using NzbDrone.Core.HealthCheck;
using NzbDrone.Core.Messaging.Events;
using NzbDrone.SignalR;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Health
{
public class HealthModule : RadarrRestModuleWithSignalR<HealthResource, HealthCheck>,
[V3ApiController]
public class HealthController : RestControllerWithSignalR<HealthResource, HealthCheck>,
IHandle<HealthCheckCompleteEvent>
{
private readonly IHealthCheckService _healthCheckService;
public HealthModule(IBroadcastSignalRMessage signalRBroadcaster, IHealthCheckService healthCheckService)
public HealthController(IBroadcastSignalRMessage signalRBroadcaster, IHealthCheckService healthCheckService)
: base(signalRBroadcaster)
{
_healthCheckService = healthCheckService;
GetResourceAll = GetHealth;
}
private List<HealthResource> GetHealth()
public override HealthResource GetResourceById(int id)
{
throw new NotImplementedException();
}
[HttpGet]
public List<HealthResource> GetHealth()
{
return _healthCheckService.Results().ToResource();
}
[NonAction]
public void Handle(HealthCheckCompleteEvent message)
{
BroadcastResourceChange(ModelAction.Sync);

View File

@ -1,6 +1,7 @@
using System;
using System.Collections.Generic;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.CustomFormats;
using NzbDrone.Core.Datastore;
using NzbDrone.Core.DecisionEngine.Specifications;
@ -10,11 +11,11 @@ using NzbDrone.Core.Movies;
using Radarr.Api.V3.Movies;
using Radarr.Http;
using Radarr.Http.Extensions;
using Radarr.Http.REST;
namespace Radarr.Api.V3.History
{
public class HistoryModule : RadarrRestModule<HistoryResource>
[V3ApiController]
public class HistoryController : Controller
{
private readonly IHistoryService _historyService;
private readonly IMovieService _movieService;
@ -22,7 +23,7 @@ namespace Radarr.Api.V3.History
private readonly IUpgradableSpecification _upgradableSpecification;
private readonly IFailedDownloadService _failedDownloadService;
public HistoryModule(IHistoryService historyService,
public HistoryController(IHistoryService historyService,
IMovieService movieService,
ICustomFormatCalculationService formatCalculator,
IUpgradableSpecification upgradableSpecification,
@ -33,12 +34,6 @@ namespace Radarr.Api.V3.History
_formatCalculator = formatCalculator;
_upgradableSpecification = upgradableSpecification;
_failedDownloadService = failedDownloadService;
GetResourcePaged = GetHistory;
Get("/since", x => GetHistorySince());
Get("/movie", x => GetMovieHistory());
Post("/failed", x => MarkAsFailed());
Post(@"/failed/(?<id>[\d]{1,10})", x => MarkAsFailed((int)x.Id));
}
protected HistoryResource MapToResource(MovieHistory model, bool includeMovie)
@ -63,10 +58,11 @@ namespace Radarr.Api.V3.History
return resource;
}
private PagingResource<HistoryResource> GetHistory(PagingResource<HistoryResource> pagingResource)
[HttpGet]
public PagingResource<HistoryResource> GetHistory(bool includeMovie)
{
var pagingResource = Request.ReadPagingResourceFromRequest<HistoryResource>();
var pagingSpec = pagingResource.MapToPagingSpec<HistoryResource, MovieHistory>("date", SortDirection.Descending);
var includeMovie = Request.GetBooleanQueryParameter("includeMovie");
var eventTypeFilter = pagingResource.Filters.FirstOrDefault(f => f.Key == "eventType");
var downloadIdFilter = pagingResource.Filters.FirstOrDefault(f => f.Key == "downloadId");
@ -83,65 +79,26 @@ namespace Radarr.Api.V3.History
pagingSpec.FilterExpressions.Add(h => h.DownloadId == downloadId);
}
return ApplyToPage(_historyService.Paged, pagingSpec, h => MapToResource(h, includeMovie));
return pagingSpec.ApplyToPage(_historyService.Paged, h => MapToResource(h, includeMovie));
}
private List<HistoryResource> GetHistorySince()
[HttpGet("since")]
public List<HistoryResource> GetHistorySince(DateTime date, MovieHistoryEventType? eventType = null, bool includeMovie = false)
{
var queryDate = Request.Query.Date;
var queryEventType = Request.Query.EventType;
if (!queryDate.HasValue)
{
throw new BadRequestException("date is missing");
}
DateTime date = DateTime.Parse(queryDate.Value);
MovieHistoryEventType? eventType = null;
var includeMovie = Request.GetBooleanQueryParameter("includeMovie");
if (queryEventType.HasValue)
{
eventType = (MovieHistoryEventType)Convert.ToInt32(queryEventType.Value);
}
return _historyService.Since(date, eventType).Select(h => MapToResource(h, includeMovie)).ToList();
}
private List<HistoryResource> GetMovieHistory()
[HttpGet("movie")]
public List<HistoryResource> GetMovieHistory(int movieId, MovieHistoryEventType? eventType = null, bool includeMovie = false)
{
var queryMovieId = Request.Query.MovieId;
var queryEventType = Request.Query.EventType;
if (!queryMovieId.HasValue)
{
throw new BadRequestException("movieId is missing");
}
int movieId = Convert.ToInt32(queryMovieId.Value);
MovieHistoryEventType? eventType = null;
var includeMovie = Request.GetBooleanQueryParameter("includeMovie");
if (queryEventType.HasValue)
{
eventType = (MovieHistoryEventType)Convert.ToInt32(queryEventType.Value);
}
return _historyService.GetByMovieId(movieId, eventType).Select(h => MapToResource(h, includeMovie)).ToList();
}
// v4 TODO: Getting the ID from the form is atypical, consider removing.
private object MarkAsFailed()
{
var id = (int)Request.Form.Id;
return MarkAsFailed(id);
}
private object MarkAsFailed(int id)
[HttpPost("failed")]
public object MarkAsFailed([FromBody] int id)
{
_failedDownloadService.MarkAsFailed(id);
return new object();
}
}

View File

@ -1,63 +1,62 @@
using System.Collections.Generic;
using FluentValidation;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.ImportLists.ImportExclusions;
using Radarr.Http;
using Radarr.Http.Extensions;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.ImportLists
{
public class ImportExclusionsModule : RadarrRestModule<ImportExclusionsResource>
[V3ApiController("exclusions")]
public class ImportExclusionsController : RestController<ImportExclusionsResource>
{
private readonly IImportExclusionsService _exclusionService;
public ImportExclusionsModule(IImportExclusionsService exclusionService)
: base("exclusions")
public ImportExclusionsController(IImportExclusionsService exclusionService)
{
_exclusionService = exclusionService;
GetResourceAll = GetAll;
DeleteResource = RemoveExclusion;
CreateResource = AddExclusion;
GetResourceById = GetById;
UpdateResource = UpdateExclusion;
Post("/bulk", x => AddExclusions());
SharedValidator.RuleFor(c => c.TmdbId).GreaterThan(0);
SharedValidator.RuleFor(c => c.MovieTitle).NotEmpty();
SharedValidator.RuleFor(c => c.MovieYear).GreaterThan(0);
}
[HttpGet]
public List<ImportExclusionsResource> GetAll()
{
return _exclusionService.GetAllExclusions().ToResource();
}
public ImportExclusionsResource GetById(int id)
public override ImportExclusionsResource GetResourceById(int id)
{
return _exclusionService.GetById(id).ToResource();
}
private void UpdateExclusion(ImportExclusionsResource exclusionResource)
[RestPutById]
public ActionResult<ImportExclusionsResource> UpdateExclusion(ImportExclusionsResource exclusionResource)
{
var model = exclusionResource.ToModel();
_exclusionService.Update(model);
return Accepted(_exclusionService.Update(model));
}
public int AddExclusion(ImportExclusionsResource exclusionResource)
[RestPostById]
public ActionResult<ImportExclusionsResource> AddExclusion(ImportExclusionsResource exclusionResource)
{
var model = exclusionResource.ToModel();
return _exclusionService.AddExclusion(model).Id;
return Created(_exclusionService.AddExclusion(model).Id);
}
public object AddExclusions()
[HttpPost("bulk")]
public object AddExclusions([FromBody] List<ImportExclusionsResource> resource)
{
var resource = Request.Body.FromJson<List<ImportExclusionsResource>>();
var newMovies = resource.ToModel();
return _exclusionService.AddExclusions(newMovies).ToResource();
}
[RestDeleteById]
public void RemoveExclusion(int id)
{
_exclusionService.RemoveExclusion(new ImportExclusion { Id = id });

View File

@ -2,14 +2,17 @@ using FluentValidation;
using NzbDrone.Core.ImportLists;
using NzbDrone.Core.Validation;
using NzbDrone.Core.Validation.Paths;
using Radarr.Http;
namespace Radarr.Api.V3.ImportLists
{
public class ImportListModule : ProviderModuleBase<ImportListResource, IImportList, ImportListDefinition>
[V3ApiController]
public class ImportListController : ProviderControllerBase<ImportListResource, IImportList, ImportListDefinition>
{
public static readonly ImportListResourceMapper ResourceMapper = new ImportListResourceMapper();
public ImportListModule(ImportListFactory importListFactory, ProfileExistsValidator profileExistsValidator)
public ImportListController(ImportListFactory importListFactory,
ProfileExistsValidator profileExistsValidator)
: base(importListFactory, "importlist", ResourceMapper)
{
SharedValidator.RuleFor(c => c.RootFolderPath).IsValidPath();

View File

@ -1,5 +1,6 @@
using System.Collections.Generic;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Configuration;
using NzbDrone.Core.ImportLists;
@ -11,11 +12,11 @@ using NzbDrone.Core.MetadataSource;
using NzbDrone.Core.Movies;
using NzbDrone.Core.Organizer;
using Radarr.Http;
using Radarr.Http.Extensions;
namespace Radarr.Api.V3.ImportLists
{
public class ImportListMoviesModule : RadarrRestModule<ImportListMoviesResource>
[V3ApiController("importlist/movie")]
public class ImportListMoviesController : Controller
{
private readonly IMovieService _movieService;
private readonly IProvideMovieInfo _movieInfo;
@ -25,14 +26,13 @@ namespace Radarr.Api.V3.ImportLists
private readonly IImportExclusionsService _importExclusionService;
private readonly IConfigService _configService;
public ImportListMoviesModule(IMovieService movieService,
public ImportListMoviesController(IMovieService movieService,
IProvideMovieInfo movieInfo,
IBuildFileNames fileNameBuilder,
IImportListMovieService listMovieService,
IImportListFactory importListFactory,
IImportExclusionsService importExclusionsService,
IConfigService configService)
: base("/importlist/movie")
{
_movieService = movieService;
_movieInfo = movieInfo;
@ -41,12 +41,11 @@ namespace Radarr.Api.V3.ImportLists
_importListFactory = importListFactory;
_importExclusionService = importExclusionsService;
_configService = configService;
Get("/", x => GetDiscoverMovies());
}
private object GetDiscoverMovies()
[HttpGet]
public object GetDiscoverMovies(bool includeRecommendations = false)
{
var includeRecommendations = Request.GetBooleanQueryParameter("includeRecommendations");
var movieLanguge = (Language)_configService.MovieInfoLanguage;
var realResults = new List<ImportListMoviesResource>();

View File

@ -1,12 +1,14 @@
using NzbDrone.Core.Indexers;
using Radarr.Http;
namespace Radarr.Api.V3.Indexers
{
public class IndexerModule : ProviderModuleBase<IndexerResource, IIndexer, IndexerDefinition>
[V3ApiController]
public class IndexerController : ProviderControllerBase<IndexerResource, IIndexer, IndexerDefinition>
{
public static readonly IndexerResourceMapper ResourceMapper = new IndexerResourceMapper();
public IndexerModule(IndexerFactory indexerFactory)
public IndexerController(IndexerFactory indexerFactory)
: base(indexerFactory, "indexer", ResourceMapper)
{
}

View File

@ -1,19 +1,17 @@
using System;
using System.Collections.Generic;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Parser.Model;
using Radarr.Http;
namespace Radarr.Api.V3.Indexers
{
public class IndexerFlagModule : RadarrRestModule<IndexerFlagResource>
[V3ApiController]
public class IndexerFlagController : Controller
{
public IndexerFlagModule()
{
GetResourceAll = GetAll;
}
private List<IndexerFlagResource> GetAll()
[HttpGet]
public List<IndexerFlagResource> GetAll()
{
return Enum.GetValues(typeof(IndexerFlags)).Cast<IndexerFlags>().Select(f => new IndexerFlagResource
{

View File

@ -1,7 +1,7 @@
using System;
using System.Collections.Generic;
using FluentValidation;
using Nancy;
using Microsoft.AspNetCore.Mvc;
using NLog;
using NzbDrone.Common.Cache;
using NzbDrone.Core.DecisionEngine;
@ -13,11 +13,13 @@ using NzbDrone.Core.Movies;
using NzbDrone.Core.Parser.Model;
using NzbDrone.Core.Profiles;
using NzbDrone.Core.Validation;
using Radarr.Http;
using HttpStatusCode = System.Net.HttpStatusCode;
namespace Radarr.Api.V3.Indexers
{
public class ReleaseModule : ReleaseModuleBase
[V3ApiController]
public class ReleaseController : ReleaseControllerBase
{
private readonly IFetchAndParseRss _rssFetcherAndParser;
private readonly ISearchForNzb _nzbSearchService;
@ -29,7 +31,7 @@ namespace Radarr.Api.V3.Indexers
private readonly ICached<RemoteMovie> _remoteMovieCache;
public ReleaseModule(IFetchAndParseRss rssFetcherAndParser,
public ReleaseController(IFetchAndParseRss rssFetcherAndParser,
ISearchForNzb nzbSearchService,
IMakeDownloadDecision downloadDecisionMaker,
IPrioritizeDownloadDecision prioritizeDownloadDecision,
@ -51,13 +53,11 @@ namespace Radarr.Api.V3.Indexers
PostValidator.RuleFor(s => s.IndexerId).ValidId();
PostValidator.RuleFor(s => s.Guid).NotEmpty();
GetResourceAll = GetReleases;
Post("/", x => DownloadRelease(ReadResourceFromRequest()));
_remoteMovieCache = cacheManager.GetCache<RemoteMovie>(GetType(), "remoteMovies");
}
private object DownloadRelease(ReleaseResource release)
[HttpPost]
public object DownloadRelease(ReleaseResource release)
{
var remoteMovie = _remoteMovieCache.Find(GetCacheKey(release));
@ -95,11 +95,12 @@ namespace Radarr.Api.V3.Indexers
return release;
}
private List<ReleaseResource> GetReleases()
[HttpGet]
public List<ReleaseResource> GetReleases(int? movieId)
{
if (Request.Query.movieId.HasValue)
if (movieId.HasValue)
{
return GetMovieReleases(Request.Query.movieId);
return GetMovieReleases(movieId.Value);
}
return GetRss();

View File

@ -1,17 +1,23 @@
using System;
using System.Collections.Generic;
using NzbDrone.Core.DecisionEngine;
using NzbDrone.Core.Profiles;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Indexers
{
public abstract class ReleaseModuleBase : RadarrRestModule<ReleaseResource>
public abstract class ReleaseControllerBase : RestController<ReleaseResource>
{
private readonly Profile _qualityProfie;
private readonly Profile _qualityProfile;
public ReleaseModuleBase(IProfileService qualityProfileService)
public ReleaseControllerBase(IProfileService qualityProfileService)
{
_qualityProfie = qualityProfileService.GetDefaultProfile(string.Empty);
_qualityProfile = qualityProfileService.GetDefaultProfile(string.Empty);
}
public override ReleaseResource GetResourceById(int id)
{
throw new NotImplementedException();
}
protected virtual List<ReleaseResource> MapDecisions(IEnumerable<DownloadDecision> decisions)
@ -34,7 +40,7 @@ namespace Radarr.Api.V3.Indexers
release.ReleaseWeight = initialWeight;
release.QualityWeight = _qualityProfie.GetIndex(release.Quality.Quality).Index * 100;
release.QualityWeight = _qualityProfile.GetIndex(release.Quality.Quality).Index * 100;
release.QualityWeight += release.Quality.Revision.Real * 10;
release.QualityWeight += release.Quality.Revision.Version;

View File

@ -2,6 +2,7 @@ using System.Collections.Generic;
using System.Linq;
using FluentValidation;
using FluentValidation.Results;
using Microsoft.AspNetCore.Mvc;
using NLog;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Datastore;
@ -10,17 +11,19 @@ using NzbDrone.Core.Download;
using NzbDrone.Core.Indexers;
using NzbDrone.Core.Parser.Model;
using NzbDrone.Core.Profiles;
using Radarr.Http;
namespace Radarr.Api.V3.Indexers
{
public class ReleasePushModule : ReleaseModuleBase
[V3ApiController("release/push")]
public class ReleasePushController : ReleaseControllerBase
{
private readonly IMakeDownloadDecision _downloadDecisionMaker;
private readonly IProcessDownloadDecisions _downloadDecisionProcessor;
private readonly IIndexerFactory _indexerFactory;
private readonly Logger _logger;
public ReleasePushModule(IMakeDownloadDecision downloadDecisionMaker,
public ReleasePushController(IMakeDownloadDecision downloadDecisionMaker,
IProcessDownloadDecisions downloadDecisionProcessor,
IIndexerFactory indexerFactory,
IProfileService qualityProfileService,
@ -36,14 +39,15 @@ namespace Radarr.Api.V3.Indexers
PostValidator.RuleFor(s => s.DownloadUrl).NotEmpty();
PostValidator.RuleFor(s => s.Protocol).NotEmpty();
PostValidator.RuleFor(s => s.PublishDate).NotEmpty();
Post("/push", x => ProcessRelease(ReadResourceFromRequest()));
}
private object ProcessRelease(ReleaseResource release)
[HttpPost]
public ActionResult<List<ReleaseResource>> Create(ReleaseResource release)
{
_logger.Info("Release pushed: {0} - {1}", release.Title, release.DownloadUrl);
ValidateResource(release);
var info = release.ToModel();
info.Guid = "PUSH-" + info.DownloadUrl;

View File

@ -1,26 +1,27 @@
using System.Text.Json;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Serializer;
using NzbDrone.Core.Localization;
using Radarr.Http;
namespace Radarr.Api.V3.Localization
{
public class LocalizationModule : RadarrRestModule<LocalizationResource>
[V3ApiController]
public class LocalizationController : Controller
{
private readonly ILocalizationService _localizationService;
private readonly JsonSerializerOptions _serializerSettings;
public LocalizationModule(ILocalizationService localizationService)
public LocalizationController(ILocalizationService localizationService)
{
_localizationService = localizationService;
_serializerSettings = STJson.GetSerializerSettings();
_serializerSettings.DictionaryKeyPolicy = null;
_serializerSettings.PropertyNamingPolicy = null;
Get("/", x => GetLocalizationDictionary());
}
private string GetLocalizationDictionary()
[HttpGet]
public string GetLocalizationDictionary()
{
return JsonSerializer.Serialize(_localizationService.GetLocalizationDictionary().ToResource(), _serializerSettings);
}

View File

@ -1,21 +1,25 @@
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Instrumentation;
using Radarr.Http;
using Radarr.Http.Extensions;
namespace Radarr.Api.V3.Logs
{
public class LogModule : RadarrRestModule<LogResource>
[V3ApiController]
public class LogController : Controller
{
private readonly ILogService _logService;
public LogModule(ILogService logService)
public LogController(ILogService logService)
{
_logService = logService;
GetResourcePaged = GetLogs;
}
private PagingResource<LogResource> GetLogs(PagingResource<LogResource> pagingResource)
[HttpGet]
public PagingResource<LogResource> GetLogs()
{
var pagingResource = Request.ReadPagingResourceFromRequest<LogResource>();
var pageSpec = pagingResource.MapToPagingSpec<LogResource, Log>();
if (pageSpec.SortKey == "time")
@ -50,7 +54,7 @@ namespace Radarr.Api.V3.Logs
}
}
var response = ApplyToPage(_logService.Paged, pageSpec, LogResourceMapper.ToResource);
var response = pageSpec.ApplyToPage(_logService.Paged, LogResourceMapper.ToResource);
if (pageSpec.SortKey == "id")
{

View File

@ -1,18 +1,20 @@
using System.Collections.Generic;
using System.Collections.Generic;
using System.IO;
using NzbDrone.Common.Disk;
using NzbDrone.Common.EnvironmentInfo;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Configuration;
using Radarr.Http;
namespace Radarr.Api.V3.Logs
{
public class LogFileModule : LogFileModuleBase
[V3ApiController("log/file")]
public class LogFileController : LogFileControllerBase
{
private readonly IAppFolderInfo _appFolderInfo;
private readonly IDiskProvider _diskProvider;
public LogFileModule(IAppFolderInfo appFolderInfo,
public LogFileController(IAppFolderInfo appFolderInfo,
IDiskProvider diskProvider,
IConfigFileProvider configFileProvider)
: base(diskProvider, configFileProvider, "")

View File

@ -1,35 +1,32 @@
using System.Collections.Generic;
using System.Collections.Generic;
using System.IO;
using System.Linq;
using Nancy;
using Nancy.Responses;
using Microsoft.AspNetCore.Mvc;
using NLog;
using NzbDrone.Common.Disk;
using NzbDrone.Core.Configuration;
using Radarr.Http;
namespace Radarr.Api.V3.Logs
{
public abstract class LogFileModuleBase : RadarrRestModule<LogFileResource>
public abstract class LogFileControllerBase : Controller
{
protected const string LOGFILE_ROUTE = @"/(?<filename>[-.a-zA-Z0-9]+?\.txt)";
protected string _resource;
private readonly IDiskProvider _diskProvider;
private readonly IConfigFileProvider _configFileProvider;
public LogFileModuleBase(IDiskProvider diskProvider,
public LogFileControllerBase(IDiskProvider diskProvider,
IConfigFileProvider configFileProvider,
string route)
: base("log/file" + route)
string resource)
{
_diskProvider = diskProvider;
_configFileProvider = configFileProvider;
GetResourceAll = GetLogFilesResponse;
Get(LOGFILE_ROUTE, options => GetLogFileResponse(options.filename));
_resource = resource;
}
private List<LogFileResource> GetLogFilesResponse()
[HttpGet]
public List<LogFileResource> GetLogFilesResponse()
{
var result = new List<LogFileResource>();
@ -45,7 +42,7 @@ namespace Radarr.Api.V3.Logs
Id = i + 1,
Filename = filename,
LastWriteTime = _diskProvider.FileGetLastWrite(file),
ContentsUrl = string.Format("{0}/api/v3/{1}/{2}", _configFileProvider.UrlBase, Resource, filename),
ContentsUrl = string.Format("{0}/api/v1/{1}/{2}", _configFileProvider.UrlBase, _resource, filename),
DownloadUrl = string.Format("{0}/{1}/{2}", _configFileProvider.UrlBase, DownloadUrlRoot, filename)
});
}
@ -53,7 +50,8 @@ namespace Radarr.Api.V3.Logs
return result.OrderByDescending(l => l.LastWriteTime).ToList();
}
private object GetLogFileResponse(string filename)
[HttpGet(@"{filename:regex([[-.a-zA-Z0-9]]+?\.txt)}")]
public IActionResult GetLogFileResponse(string filename)
{
LogManager.Flush();
@ -61,12 +59,10 @@ namespace Radarr.Api.V3.Logs
if (!_diskProvider.FileExists(filePath))
{
return new NotFoundResponse();
return NotFound();
}
var data = _diskProvider.ReadAllText(filePath);
return new TextResponse(data);
return PhysicalFile(filePath, "text/plain");
}
protected abstract IEnumerable<string> GetLogFiles();

View File

@ -1,4 +1,4 @@
using System.Collections.Generic;
using System.Collections.Generic;
using System.IO;
using System.Linq;
using System.Text.RegularExpressions;
@ -6,18 +6,20 @@ using NzbDrone.Common.Disk;
using NzbDrone.Common.EnvironmentInfo;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Configuration;
using Radarr.Http;
namespace Radarr.Api.V3.Logs
{
public class UpdateLogFileModule : LogFileModuleBase
[V3ApiController("log/file/update")]
public class UpdateLogFileController : LogFileControllerBase
{
private readonly IAppFolderInfo _appFolderInfo;
private readonly IDiskProvider _diskProvider;
public UpdateLogFileModule(IAppFolderInfo appFolderInfo,
public UpdateLogFileController(IAppFolderInfo appFolderInfo,
IDiskProvider diskProvider,
IConfigFileProvider configFileProvider)
: base(diskProvider, configFileProvider, "/update")
: base(diskProvider, configFileProvider, "update")
{
_appFolderInfo = appFolderInfo;
_diskProvider = diskProvider;

View File

@ -1,41 +1,33 @@
using System.Collections.Generic;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Languages;
using NzbDrone.Core.MediaFiles.MovieImport.Manual;
using NzbDrone.Core.Qualities;
using Radarr.Api.V3.Movies;
using Radarr.Http;
using Radarr.Http.Extensions;
namespace Radarr.Api.V3.ManualImport
{
public class ManualImportModule : RadarrRestModule<ManualImportResource>
[V3ApiController]
public class ManualImportController : Controller
{
private readonly IManualImportService _manualImportService;
public ManualImportModule(IManualImportService manualImportService)
: base("/manualimport")
public ManualImportController(IManualImportService manualImportService)
{
_manualImportService = manualImportService;
GetResourceAll = GetMediaFiles;
Post("/", x => ReprocessItems());
}
private List<ManualImportResource> GetMediaFiles()
[HttpGet]
public List<ManualImportResource> GetMediaFiles(string folder, string downloadId, int? movieId, bool filterExistingFiles = true)
{
var folder = (string)Request.Query.folder;
var downloadId = (string)Request.Query.downloadId;
var filterExistingFiles = Request.GetBooleanQueryParameter("filterExistingFiles", true);
var movieId = Request.GetNullableIntegerQueryParameter("movieId", null);
return _manualImportService.GetMediaFiles(folder, downloadId, movieId, filterExistingFiles).ToResource().Select(AddQualityWeight).ToList();
}
private object ReprocessItems()
[HttpPost]
public object ReprocessItems([FromBody] List<ManualImportReprocessResource> items)
{
var items = Request.Body.FromJson<List<ManualImportReprocessResource>>();
foreach (var item in items)
{
var processedItem = _manualImportService.ReprocessItem(item.Path, item.DownloadId, item.MovieId, item.Quality, item.Languages);

View File

@ -1,31 +1,32 @@
using System.IO;
using System.Text.RegularExpressions;
using Nancy;
using Nancy.Responses;
using Microsoft.AspNetCore.Mvc;
using Microsoft.AspNetCore.StaticFiles;
using NzbDrone.Common.Disk;
using NzbDrone.Common.EnvironmentInfo;
using NzbDrone.Common.Extensions;
using Radarr.Http;
namespace Radarr.Api.V3.MediaCovers
{
public class MediaCoverModule : RadarrV3Module
[V3ApiController]
public class MediaCoverController : Controller
{
private const string MEDIA_COVER_ROUTE = @"/(?<movieId>\d+)/(?<filename>(.+)\.(jpg|png|gif))";
private static readonly Regex RegexResizedImage = new Regex(@"-\d+\.jpg$", RegexOptions.Compiled | RegexOptions.IgnoreCase);
private readonly IAppFolderInfo _appFolderInfo;
private readonly IDiskProvider _diskProvider;
private readonly IContentTypeProvider _mimeTypeProvider;
public MediaCoverModule(IAppFolderInfo appFolderInfo, IDiskProvider diskProvider)
: base("MediaCover")
public MediaCoverController(IAppFolderInfo appFolderInfo, IDiskProvider diskProvider)
{
_appFolderInfo = appFolderInfo;
_diskProvider = diskProvider;
Get(MEDIA_COVER_ROUTE, options => GetMediaCover(options.movieId, options.filename));
_mimeTypeProvider = new FileExtensionContentTypeProvider();
}
private object GetMediaCover(int movieId, string filename)
[HttpGet(@"author/{movieId:int}/{filename:regex((.+)\.(jpg|png|gif))}")]
public IActionResult GetMediaCover(int movieId, string filename)
{
var filePath = Path.Combine(_appFolderInfo.GetAppDataPath(), "MediaCover", movieId.ToString(), filename);
@ -36,13 +37,23 @@ namespace Radarr.Api.V3.MediaCovers
var basefilePath = RegexResizedImage.Replace(filePath, ".jpg");
if (basefilePath == filePath || !_diskProvider.FileExists(basefilePath))
{
return new NotFoundResponse();
return NotFound();
}
filePath = basefilePath;
}
return new StreamResponse(() => File.OpenRead(filePath), MimeTypes.GetMimeType(filePath));
return PhysicalFile(filePath, GetContentType(filePath));
}
private string GetContentType(string filePath)
{
if (!_mimeTypeProvider.TryGetContentType(filePath, out var contentType))
{
contentType = "application/octet-stream";
}
return contentType;
}
}
}

View File

@ -1,12 +1,14 @@
using NzbDrone.Core.Extras.Metadata;
using Radarr.Http;
namespace Radarr.Api.V3.Metadata
{
public class MetadataModule : ProviderModuleBase<MetadataResource, IMetadata, MetadataDefinition>
[V3ApiController]
public class MetadataController : ProviderControllerBase<MetadataResource, IMetadata, MetadataDefinition>
{
public static readonly MetadataResourceMapper ResourceMapper = new MetadataResourceMapper();
public MetadataModule(IMetadataFactory metadataFactory)
public MetadataController(IMetadataFactory metadataFactory)
: base(metadataFactory, "metadata", ResourceMapper)
{
}

View File

@ -1,7 +1,6 @@
using System;
using System.Collections.Generic;
using System.Linq;
using Nancy;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.CustomFormats;
using NzbDrone.Core.Datastore.Events;
using NzbDrone.Core.DecisionEngine.Specifications;
@ -16,12 +15,14 @@ using NzbDrone.Core.Parser.Model;
using NzbDrone.SignalR;
using Radarr.Api.V3.CustomFormats;
using Radarr.Http;
using Radarr.Http.Extensions;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
using BadRequestException = Radarr.Http.REST.BadRequestException;
namespace Radarr.Api.V3.MovieFiles
{
public class MovieFileModule : RadarrRestModuleWithSignalR<MovieFileResource, MovieFile>,
[V3ApiController]
public class MovieFileController : RestControllerWithSignalR<MovieFileResource, MovieFile>,
IHandle<MovieFileAddedEvent>,
IHandle<MovieFileDeletedEvent>
{
@ -31,7 +32,7 @@ namespace Radarr.Api.V3.MovieFiles
private readonly ICustomFormatCalculationService _formatCalculator;
private readonly IUpgradableSpecification _qualityUpgradableSpecification;
public MovieFileModule(IBroadcastSignalRMessage signalRBroadcaster,
public MovieFileController(IBroadcastSignalRMessage signalRBroadcaster,
IMediaFileService mediaFileService,
IDeleteMediaFiles mediaFileDeletionService,
IMovieService movieService,
@ -44,17 +45,9 @@ namespace Radarr.Api.V3.MovieFiles
_movieService = movieService;
_formatCalculator = formatCalculator;
_qualityUpgradableSpecification = qualityUpgradableSpecification;
GetResourceById = GetMovieFile;
GetResourceAll = GetMovieFiles;
UpdateResource = SetMovieFile;
DeleteResource = DeleteMovieFile;
Put("/editor", movieFiles => SetMovieFile());
Delete("/bulk", movieFiles => DeleteMovieFiles());
}
private MovieFileResource GetMovieFile(int id)
public override MovieFileResource GetResourceById(int id)
{
var movieFile = _mediaFileService.GetMovie(id);
var movie = _movieService.GetMovie(movieFile.MovieId);
@ -65,21 +58,18 @@ namespace Radarr.Api.V3.MovieFiles
return resource;
}
private List<MovieFileResource> GetMovieFiles()
[HttpGet]
public List<MovieFileResource> GetMovieFiles(int? movieId, [FromQuery] List<int> movieFileIds)
{
var movieIdQuery = Request.Query.MovieId;
var movieFileIdsQuery = Request.Query.MovieFileIds;
if (!movieIdQuery.HasValue && !movieFileIdsQuery.HasValue)
if (!movieId.HasValue && !movieFileIds.Any())
{
throw new BadRequestException("movieId or movieFileIds must be provided");
}
if (movieIdQuery.HasValue)
if (movieId.HasValue)
{
int movieId = Convert.ToInt32(movieIdQuery.Value);
var movie = _movieService.GetMovie(movieId);
var file = _mediaFileService.GetFilesByMovie(movieId).FirstOrDefault();
var movie = _movieService.GetMovie(movieId.Value);
var file = _mediaFileService.GetFilesByMovie(movieId.Value).FirstOrDefault();
if (file == null)
{
@ -94,12 +84,6 @@ namespace Radarr.Api.V3.MovieFiles
}
else
{
string movieFileIdsValue = movieFileIdsQuery.Value.ToString();
var movieFileIds = movieFileIdsValue.Split(new[] { ',' }, StringSplitOptions.RemoveEmptyEntries)
.Select(e => Convert.ToInt32(e))
.ToList();
var movieFiles = _mediaFileService.GetMovies(movieFileIds);
return movieFiles.GroupBy(e => e.MovieId)
@ -109,7 +93,8 @@ namespace Radarr.Api.V3.MovieFiles
}
}
private void SetMovieFile(MovieFileResource movieFileResource)
[RestPutById]
public ActionResult<MovieFileResource> SetMovieFile(MovieFileResource movieFileResource)
{
var movieFile = _mediaFileService.GetMovie(movieFileResource.Id);
movieFile.IndexerFlags = (IndexerFlags)movieFileResource.IndexerFlags;
@ -127,11 +112,12 @@ namespace Radarr.Api.V3.MovieFiles
}
_mediaFileService.Update(movieFile);
return Accepted(movieFile.Id);
}
private object SetMovieFile()
[HttpPut("editor")]
public object SetMovieFile([FromBody] MovieFileListResource resource)
{
var resource = Request.Body.FromJson<MovieFileListResource>();
var movieFiles = _mediaFileService.GetMovies(resource.MovieFileIds);
foreach (var movieFile in movieFiles)
@ -172,11 +158,11 @@ namespace Radarr.Api.V3.MovieFiles
var movie = _movieService.GetMovie(movieFiles.First().MovieId);
return ResponseWithCode(movieFiles.ConvertAll(f => f.ToResource(movie, _qualityUpgradableSpecification)),
HttpStatusCode.Accepted);
return Accepted(movieFiles.ConvertAll(f => f.ToResource(movie, _qualityUpgradableSpecification)));
}
private void DeleteMovieFile(int id)
[RestDeleteById]
public void DeleteMovieFile(int id)
{
var movieFile = _mediaFileService.GetMovie(id);
@ -190,9 +176,9 @@ namespace Radarr.Api.V3.MovieFiles
_mediaFileDeletionService.DeleteMovieFile(movie, movieFile);
}
private object DeleteMovieFiles()
[HttpDelete("bulk")]
public object DeleteMovieFiles([FromBody] MovieFileListResource resource)
{
var resource = Request.Body.FromJson<MovieFileListResource>();
var movieFiles = _mediaFileService.GetMovies(resource.MovieFileIds);
var movie = _movieService.GetMovie(movieFiles.First().MovieId);
@ -204,11 +190,13 @@ namespace Radarr.Api.V3.MovieFiles
return new object();
}
[NonAction]
public void Handle(MovieFileAddedEvent message)
{
BroadcastResourceChange(ModelAction.Updated, message.MovieFile.Id);
}
[NonAction]
public void Handle(MovieFileDeletedEvent message)
{
BroadcastResourceChange(ModelAction.Deleted, message.MovieFile.Id);

View File

@ -0,0 +1,36 @@
using System;
using System.Collections.Generic;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Movies.AlternativeTitles;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Movies
{
[V3ApiController("alttitle")]
public class AlternativeTitleController : RestController<AlternativeTitleResource>
{
private readonly IAlternativeTitleService _altTitleService;
public AlternativeTitleController(IAlternativeTitleService altTitleService)
{
_altTitleService = altTitleService;
}
public override AlternativeTitleResource GetResourceById(int id)
{
return _altTitleService.GetById(id).ToResource();
}
[HttpGet]
public List<AlternativeTitleResource> GetAltTitles(int? movieId)
{
if (movieId.HasValue)
{
return _altTitleService.GetAllTitlesForMovie(movieId.Value).ToResource();
}
return _altTitleService.GetAllTitles().ToResource();
}
}
}

View File

@ -1,46 +0,0 @@
using System;
using System.Collections.Generic;
using NzbDrone.Core.Messaging.Events;
using NzbDrone.Core.Movies;
using NzbDrone.Core.Movies.AlternativeTitles;
using Radarr.Http;
namespace Radarr.Api.V3.Movies
{
public class AlternativeTitleModule : RadarrRestModule<AlternativeTitleResource>
{
private readonly IAlternativeTitleService _altTitleService;
private readonly IMovieService _movieService;
private readonly IEventAggregator _eventAggregator;
public AlternativeTitleModule(IAlternativeTitleService altTitleService, IMovieService movieService, IEventAggregator eventAggregator)
: base("/alttitle")
{
_altTitleService = altTitleService;
_movieService = movieService;
_eventAggregator = eventAggregator;
GetResourceById = GetAltTitle;
GetResourceAll = GetAltTitles;
}
private AlternativeTitleResource GetAltTitle(int id)
{
return _altTitleService.GetById(id).ToResource();
}
private List<AlternativeTitleResource> GetAltTitles()
{
var movieIdQuery = Request.Query.MovieId;
if (movieIdQuery.HasValue)
{
int movieId = Convert.ToInt32(movieIdQuery.Value);
return _altTitleService.GetAllTitlesForMovie(movieId).ToResource();
}
return _altTitleService.GetAllTitles().ToResource();
}
}
}

View File

@ -0,0 +1,25 @@
using NzbDrone.Common.Cache;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Movies
{
[V3ApiController("altyear")]
public class AlternativeYearController : RestController<AlternativeYearResource>
{
private readonly ICached<int> _yearCache;
public AlternativeYearController(ICacheManager cacheManager)
{
_yearCache = cacheManager.GetCache<int>(GetType(), "altYears");
}
public override AlternativeYearResource GetResourceById(int id)
{
return new AlternativeYearResource
{
Year = _yearCache.Find(id.ToString())
};
}
}
}

View File

@ -1,31 +0,0 @@
using NzbDrone.Common.Cache;
using NzbDrone.Core.Messaging.Events;
using NzbDrone.Core.Movies;
using Radarr.Http;
namespace Radarr.Api.V3.Movies
{
public class AlternativeYearModule : RadarrRestModule<AlternativeYearResource>
{
private readonly IMovieService _movieService;
private readonly ICached<int> _yearCache;
private readonly IEventAggregator _eventAggregator;
public AlternativeYearModule(IMovieService movieService, ICacheManager cacheManager, IEventAggregator eventAggregator)
: base("/altyear")
{
_movieService = movieService;
GetResourceById = GetYear;
_yearCache = cacheManager.GetCache<int>(GetType(), "altYears");
_eventAggregator = eventAggregator;
}
private AlternativeYearResource GetYear(int id)
{
return new AlternativeYearResource
{
Year = _yearCache.Find(id.ToString())
};
}
}
}

View File

@ -4,7 +4,7 @@ using System.IO;
using System.Linq;
using System.Threading.Tasks;
using FluentValidation;
using Nancy;
using Microsoft.AspNetCore.Mvc;
using NLog;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Configuration;
@ -25,10 +25,13 @@ using NzbDrone.Core.Validation.Paths;
using NzbDrone.SignalR;
using Radarr.Http;
using Radarr.Http.Extensions;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.Movies
{
public class MovieModule : RadarrRestModuleWithSignalR<MovieResource, Movie>,
[V3ApiController]
public class MovieController : RestControllerWithSignalR<MovieResource, Movie>,
IHandle<MovieImportedEvent>,
IHandle<MovieFileDeletedEvent>,
IHandle<MovieUpdatedEvent>,
@ -46,7 +49,7 @@ namespace Radarr.Api.V3.Movies
private readonly IConfigService _configService;
private readonly Logger _logger;
public MovieModule(IBroadcastSignalRMessage signalRBroadcaster,
public MovieController(IBroadcastSignalRMessage signalRBroadcaster,
IMovieService moviesService,
IMovieTranslationService movieTranslationService,
IAddMovieService addMovieService,
@ -75,12 +78,6 @@ namespace Radarr.Api.V3.Movies
_commandQueueManager = commandQueueManager;
_logger = logger;
GetResourceAll = AllMovie;
GetResourceById = GetMovie;
CreateResource = AddMovie;
UpdateResource = UpdateMovie;
DeleteResource = DeleteMovie;
SharedValidator.RuleFor(s => s.QualityProfileId).ValidId();
SharedValidator.RuleFor(s => s.Path)
@ -107,16 +104,16 @@ namespace Radarr.Api.V3.Movies
PutValidator.RuleFor(s => s.Path).IsValidPath();
}
private List<MovieResource> AllMovie()
[HttpGet]
public List<MovieResource> AllMovie(int? tmdbId)
{
var tmdbId = Request.GetIntegerQueryParameter("tmdbId");
var moviesResources = new List<MovieResource>();
Dictionary<string, FileInfo> coverFileInfos = null;
if (tmdbId > 0)
if (tmdbId.HasValue)
{
var movie = _moviesService.FindByTmdbId(tmdbId);
var movie = _moviesService.FindByTmdbId(tmdbId.Value);
if (movie != null)
{
@ -153,7 +150,7 @@ namespace Radarr.Api.V3.Movies
return moviesResources;
}
private MovieResource GetMovie(int id)
public override MovieResource GetResourceById(int id)
{
var movie = _moviesService.GetMovie(id);
return MapToResource(movie);
@ -206,14 +203,16 @@ namespace Radarr.Api.V3.Movies
return translation;
}
private int AddMovie(MovieResource moviesResource)
[RestPostById]
public ActionResult<MovieResource> AddMovie(MovieResource moviesResource)
{
var movie = _addMovieService.AddMovie(moviesResource.ToModel());
return movie.Id;
return Created(movie.Id);
}
private void UpdateMovie(MovieResource moviesResource)
[RestPutById]
public ActionResult<MovieResource> UpdateMovie(MovieResource moviesResource)
{
var moveFiles = Request.GetBooleanQueryParameter("moveFiles");
var movie = _moviesService.GetMovie(moviesResource.Id);
@ -241,9 +240,12 @@ namespace Radarr.Api.V3.Movies
var translation = GetMovieTranslation(translations, movie, (Language)_configService.MovieInfoLanguage);
BroadcastResourceChange(ModelAction.Updated, updatedMovie.ToResource(availDelay, translation, _qualityUpgradableSpecification));
return Accepted(moviesResource.Id);
}
private void DeleteMovie(int id)
[RestDeleteById]
public void DeleteMovie(int id)
{
var addExclusion = Request.GetBooleanQueryParameter("addImportExclusion");
var deleteFiles = Request.GetBooleanQueryParameter("deleteFiles");
@ -261,6 +263,7 @@ namespace Radarr.Api.V3.Movies
_coverMapper.ConvertToLocalUrls(movies.Select(x => Tuple.Create(x.Id, x.Images.AsEnumerable())), coverFileInfos);
}
[NonAction]
public void Handle(MovieImportedEvent message)
{
var availDelay = _configService.AvailabilityDelay;
@ -269,6 +272,7 @@ namespace Radarr.Api.V3.Movies
BroadcastResourceChange(ModelAction.Updated, message.ImportedMovie.Movie.ToResource(availDelay, translation, _qualityUpgradableSpecification));
}
[NonAction]
public void Handle(MovieFileDeletedEvent message)
{
if (message.Reason == DeleteMediaFileReason.Upgrade)
@ -279,6 +283,7 @@ namespace Radarr.Api.V3.Movies
BroadcastResourceChange(ModelAction.Updated, message.MovieFile.MovieId);
}
[NonAction]
public void Handle(MovieUpdatedEvent message)
{
var availDelay = _configService.AvailabilityDelay;
@ -287,6 +292,7 @@ namespace Radarr.Api.V3.Movies
BroadcastResourceChange(ModelAction.Updated, message.Movie.ToResource(availDelay, translation, _qualityUpgradableSpecification));
}
[NonAction]
public void Handle(MovieEditedEvent message)
{
var availDelay = _configService.AvailabilityDelay;
@ -295,6 +301,7 @@ namespace Radarr.Api.V3.Movies
BroadcastResourceChange(ModelAction.Updated, message.Movie.ToResource(availDelay, translation, _qualityUpgradableSpecification));
}
[NonAction]
public void Handle(MoviesDeletedEvent message)
{
foreach (var movie in message.Movies)
@ -303,6 +310,7 @@ namespace Radarr.Api.V3.Movies
}
}
[NonAction]
public void Handle(MovieRenamedEvent message)
{
var availDelay = _configService.AvailabilityDelay;
@ -311,6 +319,7 @@ namespace Radarr.Api.V3.Movies
BroadcastResourceChange(ModelAction.Updated, message.Movie.ToResource(availDelay, translation, _qualityUpgradableSpecification));
}
[NonAction]
public void Handle(MediaCoversUpdatedEvent message)
{
if (message.Updated)

View File

@ -1,34 +1,32 @@
using System.Collections.Generic;
using System.Linq;
using Nancy;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.DecisionEngine.Specifications;
using NzbDrone.Core.Messaging.Commands;
using NzbDrone.Core.Movies;
using NzbDrone.Core.Movies.Commands;
using Radarr.Http.Extensions;
using Radarr.Http;
namespace Radarr.Api.V3.Movies
{
public class MovieEditorModule : RadarrV3Module
[V3ApiController("movie/editor")]
public class MovieEditorController : Controller
{
private readonly IMovieService _movieService;
private readonly IManageCommandQueue _commandQueueManager;
private readonly IUpgradableSpecification _upgradableSpecification;
public MovieEditorModule(IMovieService movieService, IManageCommandQueue commandQueueManager, IUpgradableSpecification upgradableSpecification)
: base("/movie/editor")
public MovieEditorController(IMovieService movieService, IManageCommandQueue commandQueueManager, IUpgradableSpecification upgradableSpecification)
{
_movieService = movieService;
_commandQueueManager = commandQueueManager;
_upgradableSpecification = upgradableSpecification;
Put("/", movie => SaveAll());
Delete("/", movie => DeleteMovies());
}
private object SaveAll()
[HttpPut]
public IActionResult SaveAll([FromBody] MovieEditorResource resource)
{
var resource = Request.Body.FromJson<MovieEditorResource>();
var moviesToUpdate = _movieService.GetMovies(resource.MovieIds);
var moviesToMove = new List<BulkMoveMovie>();
@ -88,15 +86,12 @@ namespace Radarr.Api.V3.Movies
});
}
return ResponseWithCode(_movieService.UpdateMovie(moviesToUpdate, !resource.MoveFiles)
.ToResource(0, _upgradableSpecification),
HttpStatusCode.Accepted);
return Accepted(_movieService.UpdateMovie(moviesToUpdate, !resource.MoveFiles).ToResource(0, _upgradableSpecification));
}
private object DeleteMovies()
[HttpDelete]
public object DeleteMovies([FromBody] MovieEditorResource resource)
{
var resource = Request.Body.FromJson<MovieEditorResource>();
_movieService.DeleteMovies(resource.MovieIds, resource.DeleteFiles, resource.AddImportExclusion);
return new object();

View File

@ -0,0 +1,33 @@
using System;
using System.Collections.Generic;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Movies;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Movies
{
[V3ApiController("movie/import")]
public class MovieImportController : RestController<MovieResource>
{
private readonly IAddMovieService _addMovieService;
public MovieImportController(IAddMovieService addMovieService)
{
_addMovieService = addMovieService;
}
public override MovieResource GetResourceById(int id)
{
throw new NotImplementedException();
}
[HttpPost]
public object Import([FromBody] List<MovieResource> resource)
{
var newMovies = resource.ToModel();
return _addMovieService.AddMovies(newMovies).ToResource(0);
}
}
}

View File

@ -1,28 +0,0 @@
using System.Collections.Generic;
using Nancy;
using NzbDrone.Core.Movies;
using Radarr.Http;
using Radarr.Http.Extensions;
namespace Radarr.Api.V3.Movies
{
public class MovieImportModule : RadarrRestModule<MovieResource>
{
private readonly IAddMovieService _addMovieService;
public MovieImportModule(IAddMovieService addMovieService)
: base("/movie/import")
{
_addMovieService = addMovieService;
Post("/", x => Import());
}
private object Import()
{
var resource = Request.Body.FromJson<List<MovieResource>>();
var newMovies = resource.ToModel();
return _addMovieService.AddMovies(newMovies).ToResource(0);
}
}
}

View File

@ -1,6 +1,7 @@
using System;
using System.Collections.Generic;
using System.Linq;
using Nancy;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Configuration;
using NzbDrone.Core.Languages;
using NzbDrone.Core.MediaCover;
@ -12,7 +13,8 @@ using Radarr.Http.REST;
namespace Radarr.Api.V3.Movies
{
public class MovieLookupModule : RadarrRestModule<MovieResource>
[V3ApiController("movie/lookup")]
public class MovieLookupController : RestController<MovieResource>
{
private readonly ISearchForNewMovie _searchProxy;
private readonly IProvideMovieInfo _movieInfo;
@ -20,40 +22,36 @@ namespace Radarr.Api.V3.Movies
private readonly IMapCoversToLocal _coverMapper;
private readonly IConfigService _configService;
public MovieLookupModule(ISearchForNewMovie searchProxy,
public MovieLookupController(ISearchForNewMovie searchProxy,
IProvideMovieInfo movieInfo,
IBuildFileNames fileNameBuilder,
IMapCoversToLocal coverMapper,
IConfigService configService)
: base("/movie/lookup")
{
_movieInfo = movieInfo;
_searchProxy = searchProxy;
_fileNameBuilder = fileNameBuilder;
_coverMapper = coverMapper;
_configService = configService;
Get("/", x => Search());
Get("/tmdb", x => SearchByTmdbId());
Get("/imdb", x => SearchByImdbId());
}
private object SearchByTmdbId()
public override MovieResource GetResourceById(int id)
{
int tmdbId = -1;
if (int.TryParse(Request.Query.tmdbId, out tmdbId))
{
var availDelay = _configService.AvailabilityDelay;
var result = _movieInfo.GetMovieInfo(tmdbId).Item1;
var translation = result.Translations.FirstOrDefault(t => t.Language == (Language)_configService.MovieInfoLanguage);
return result.ToResource(availDelay, translation);
}
throw new BadRequestException("Tmdb Id was not valid");
throw new NotImplementedException();
}
private object SearchByImdbId()
[HttpGet("tmdb")]
public object SearchByTmdbId(int tmdbId)
{
var availDelay = _configService.AvailabilityDelay;
var result = _movieInfo.GetMovieInfo(tmdbId).Item1;
var translation = result.Translations.FirstOrDefault(t => t.Language == (Language)_configService.MovieInfoLanguage);
return result.ToResource(availDelay, translation);
}
[HttpGet("imdb")]
public object SearchByImdbId(string imdbId)
{
string imdbId = Request.Query.imdbId;
var result = _movieInfo.GetMovieByImdbId(imdbId);
var availDelay = _configService.AvailabilityDelay;
@ -61,9 +59,10 @@ namespace Radarr.Api.V3.Movies
return result.ToResource(availDelay, translation);
}
private object Search()
[HttpGet]
public object Search([FromQuery] string term)
{
var searchResults = _searchProxy.SearchForNewMovie((string)Request.Query.term);
var searchResults = _searchProxy.SearchForNewMovie(term);
return MapToResource(searchResults);
}

View File

@ -0,0 +1,25 @@
using System;
using System.Collections.Generic;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.MediaFiles;
using Radarr.Http;
namespace Radarr.Api.V3.Movies
{
[V3ApiController("rename")]
public class RenameMovieController : Controller
{
private readonly IRenameMovieFileService _renameMovieFileService;
public RenameMovieController(IRenameMovieFileService renameMovieFileService)
{
_renameMovieFileService = renameMovieFileService;
}
[HttpGet]
public List<RenameMovieResource> GetMovies(int movieId)
{
return _renameMovieFileService.GetRenamePreviews(movieId).ToResource();
}
}
}

View File

@ -1,36 +0,0 @@
using System.Collections.Generic;
using NzbDrone.Core.MediaFiles;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Movies
{
public class RenameMovieModule : RadarrRestModule<RenameMovieResource>
{
private readonly IRenameMovieFileService _renameMovieFileService;
public RenameMovieModule(IRenameMovieFileService renameMovieFileService)
: base("rename")
{
_renameMovieFileService = renameMovieFileService;
GetResourceAll = GetMovies;
}
private List<RenameMovieResource> GetMovies()
{
int movieId;
if (Request.Query.MovieId.HasValue)
{
movieId = (int)Request.Query.MovieId;
}
else
{
throw new BadRequestException("movieId is missing");
}
return _renameMovieFileService.GetRenamePreviews(movieId).ToResource();
}
}
}

View File

@ -1,12 +1,14 @@
using NzbDrone.Core.Notifications;
using Radarr.Http;
namespace Radarr.Api.V3.Notifications
{
public class NotificationModule : ProviderModuleBase<NotificationResource, INotification, NotificationDefinition>
[V3ApiController]
public class NotificationController : ProviderControllerBase<NotificationResource, INotification, NotificationDefinition>
{
public static readonly NotificationResourceMapper ResourceMapper = new NotificationResourceMapper();
public NotificationModule(NotificationFactory notificationFactory)
public NotificationController(NotificationFactory notificationFactory)
: base(notificationFactory, "notification", ResourceMapper)
{
}

View File

@ -1,30 +1,28 @@
using System.Collections.Generic;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Configuration;
using NzbDrone.Core.Exceptions;
using NzbDrone.Core.Parser;
using Radarr.Api.V3.Movies;
using Radarr.Http;
namespace Radarr.Api.V3.Parse
{
public class ParseModule : RadarrRestModule<ParseResource>
[V3ApiController]
public class ParseController : Controller
{
private readonly IParsingService _parsingService;
private readonly IConfigService _configService;
public ParseModule(IParsingService parsingService, IConfigService configService)
public ParseController(IParsingService parsingService, IConfigService configService)
{
_parsingService = parsingService;
_configService = configService;
GetResourceSingle = Parse;
}
private ParseResource Parse()
[HttpGet]
public ParseResource Parse(string title)
{
var title = Request.Query.Title.Value as string;
if (title.IsNullOrWhiteSpace())
{
return null;

View File

@ -1,26 +1,23 @@
using System.Collections.Generic;
using FluentValidation;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Profiles.Delay;
using Radarr.Http;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
using Radarr.Http.Validation;
namespace Radarr.Api.V3.Profiles.Delay
{
public class DelayProfileModule : RadarrRestModule<DelayProfileResource>
[V3ApiController]
public class DelayProfileController : RestController<DelayProfileResource>
{
private readonly IDelayProfileService _delayProfileService;
public DelayProfileModule(IDelayProfileService delayProfileService, DelayProfileTagInUseValidator tagInUseValidator)
public DelayProfileController(IDelayProfileService delayProfileService, DelayProfileTagInUseValidator tagInUseValidator)
{
_delayProfileService = delayProfileService;
GetResourceAll = GetAll;
GetResourceById = GetById;
UpdateResource = Update;
CreateResource = Create;
DeleteResource = DeleteProfile;
SharedValidator.RuleFor(d => d.Tags).NotEmpty().When(d => d.Id != 1);
SharedValidator.RuleFor(d => d.Tags).EmptyCollection<DelayProfileResource, int>().When(d => d.Id == 1);
SharedValidator.RuleFor(d => d.Tags).SetValidator(tagInUseValidator);
@ -36,15 +33,17 @@ namespace Radarr.Api.V3.Profiles.Delay
});
}
private int Create(DelayProfileResource resource)
[RestPostById]
public ActionResult<DelayProfileResource> Create(DelayProfileResource resource)
{
var model = resource.ToModel();
model = _delayProfileService.Add(model);
return model.Id;
return Created(model.Id);
}
private void DeleteProfile(int id)
[RestDeleteById]
public void DeleteProfile(int id)
{
if (id == 1)
{
@ -54,18 +53,21 @@ namespace Radarr.Api.V3.Profiles.Delay
_delayProfileService.Delete(id);
}
private void Update(DelayProfileResource resource)
[RestPutById]
public ActionResult<DelayProfileResource> Update(DelayProfileResource resource)
{
var model = resource.ToModel();
_delayProfileService.Update(model);
return Accepted(model.Id);
}
private DelayProfileResource GetById(int id)
public override DelayProfileResource GetResourceById(int id)
{
return _delayProfileService.Get(id).ToResource();
}
private List<DelayProfileResource> GetAll()
[HttpGet]
public List<DelayProfileResource> GetAll()
{
return _delayProfileService.All().ToResource();
}

View File

@ -1,19 +1,16 @@
using System.Collections.Generic;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Languages;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Profiles.Languages
{
public class LanguageModule : RadarrRestModule<LanguageResource>
[V3ApiController]
public class LanguageController : RestController<LanguageResource>
{
public LanguageModule()
{
GetResourceAll = GetAll;
GetResourceById = GetById;
}
private LanguageResource GetById(int id)
public override LanguageResource GetResourceById(int id)
{
var language = (Language)id;
@ -24,7 +21,8 @@ namespace Radarr.Api.V3.Profiles.Languages
};
}
private List<LanguageResource> GetAll()
[HttpGet]
public List<LanguageResource> GetAll()
{
var languageResources = Language.All.Select(l => new LanguageResource
{

View File

@ -1,19 +1,23 @@
using System.Collections.Generic;
using System.Linq;
using FluentValidation;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.CustomFormats;
using NzbDrone.Core.Profiles;
using Radarr.Http;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.Profiles.Quality
{
public class QualityProfileModule : RadarrRestModule<QualityProfileResource>
[V3ApiController]
public class QualityProfileController : RestController<QualityProfileResource>
{
private readonly IProfileService _profileService;
private readonly ICustomFormatService _formatService;
public QualityProfileModule(IProfileService profileService, ICustomFormatService formatService)
public QualityProfileController(IProfileService profileService, ICustomFormatService formatService)
{
_profileService = profileService;
_formatService = formatService;
@ -38,39 +42,39 @@ namespace Radarr.Api.V3.Profiles.Quality
context.AddFailure("Minimum Custom Format Score can never be satisfied");
}
});
GetResourceAll = GetAll;
GetResourceById = GetById;
UpdateResource = Update;
CreateResource = Create;
DeleteResource = DeleteProfile;
}
private int Create(QualityProfileResource resource)
[RestPostById]
public ActionResult<QualityProfileResource> Create(QualityProfileResource resource)
{
var model = resource.ToModel();
model = _profileService.Add(model);
return model.Id;
return Created(model.Id);
}
private void DeleteProfile(int id)
[RestDeleteById]
public void DeleteProfile(int id)
{
_profileService.Delete(id);
}
private void Update(QualityProfileResource resource)
[RestPutById]
public ActionResult<QualityProfileResource> Update(QualityProfileResource resource)
{
var model = resource.ToModel();
_profileService.Update(model);
return Accepted(model.Id);
}
private QualityProfileResource GetById(int id)
public override QualityProfileResource GetResourceById(int id)
{
return _profileService.Get(id).ToResource();
}
private List<QualityProfileResource> GetAll()
[HttpGet]
public List<QualityProfileResource> GetAll()
{
return _profileService.All().ToResource();
}

View File

@ -1,21 +1,21 @@
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Profiles;
using Radarr.Http;
namespace Radarr.Api.V3.Profiles.Quality
{
public class QualityProfileSchemaModule : RadarrRestModule<QualityProfileResource>
[V3ApiController("qualityprofile/schema")]
public class QualityProfileSchemaController : Controller
{
private readonly IProfileService _profileService;
public QualityProfileSchemaModule(IProfileService profileService)
: base("/qualityprofile/schema")
public QualityProfileSchemaController(IProfileService profileService)
{
_profileService = profileService;
GetResourceSingle = GetSchema;
}
private QualityProfileResource GetSchema()
[HttpGet]
public QualityProfileResource GetSchema()
{
var qualityProfile = _profileService.GetDefaultProfile(string.Empty);

View File

@ -2,16 +2,17 @@ using System.Collections.Generic;
using System.Linq;
using FluentValidation;
using FluentValidation.Results;
using Nancy;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Serializer;
using NzbDrone.Core.ThingiProvider;
using NzbDrone.Core.Validation;
using Radarr.Http;
using Radarr.Http.Extensions;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3
{
public abstract class ProviderModuleBase<TProviderResource, TProvider, TProviderDefinition> : RadarrRestModule<TProviderResource>
public abstract class ProviderControllerBase<TProviderResource, TProvider, TProviderDefinition> : RestController<TProviderResource>
where TProviderDefinition : ProviderDefinition, new()
where TProvider : IProvider
where TProviderResource : ProviderResource<TProviderResource>, new()
@ -19,23 +20,11 @@ namespace Radarr.Api.V3
private readonly IProviderFactory<TProvider, TProviderDefinition> _providerFactory;
private readonly ProviderResourceMapper<TProviderResource, TProviderDefinition> _resourceMapper;
protected ProviderModuleBase(IProviderFactory<TProvider, TProviderDefinition> providerFactory, string resource, ProviderResourceMapper<TProviderResource, TProviderDefinition> resourceMapper)
: base(resource)
protected ProviderControllerBase(IProviderFactory<TProvider, TProviderDefinition> providerFactory, string resource, ProviderResourceMapper<TProviderResource, TProviderDefinition> resourceMapper)
{
_providerFactory = providerFactory;
_resourceMapper = resourceMapper;
Get("schema", x => GetTemplates());
Post("test", x => Test(ReadResourceFromRequest(true)));
Post("testall", x => TestAll());
Post("action/{action}", x => RequestAction(x.action, ReadResourceFromRequest(true, true)));
GetResourceAll = GetAll;
GetResourceById = GetProviderById;
CreateResource = CreateProvider;
UpdateResource = UpdateProvider;
DeleteResource = DeleteProvider;
SharedValidator.RuleFor(c => c.Name).NotEmpty();
SharedValidator.RuleFor(c => c.Name).Must((v, c) => !_providerFactory.All().Any(p => p.Name == c && p.Id != v.Id)).WithMessage("Should be unique");
SharedValidator.RuleFor(c => c.Implementation).NotEmpty();
@ -44,7 +33,7 @@ namespace Radarr.Api.V3
PostValidator.RuleFor(c => c.Fields).NotNull();
}
private TProviderResource GetProviderById(int id)
public override TProviderResource GetResourceById(int id)
{
var definition = _providerFactory.Get(id);
_providerFactory.SetProviderCharacteristics(definition);
@ -52,7 +41,8 @@ namespace Radarr.Api.V3
return _resourceMapper.ToResource(definition);
}
private List<TProviderResource> GetAll()
[HttpGet]
public List<TProviderResource> GetAll()
{
var providerDefinitions = _providerFactory.All().OrderBy(p => p.ImplementationName);
@ -68,7 +58,8 @@ namespace Radarr.Api.V3
return result.OrderBy(p => p.Name).ToList();
}
private int CreateProvider(TProviderResource providerResource)
[RestPostById]
public ActionResult<TProviderResource> CreateProvider(TProviderResource providerResource)
{
var providerDefinition = GetDefinition(providerResource, false);
@ -79,10 +70,11 @@ namespace Radarr.Api.V3
providerDefinition = _providerFactory.Create(providerDefinition);
return providerDefinition.Id;
return Created(providerDefinition.Id);
}
private void UpdateProvider(TProviderResource providerResource)
[RestPutById]
public ActionResult<TProviderResource> UpdateProvider(TProviderResource providerResource)
{
var providerDefinition = GetDefinition(providerResource, false);
var forceSave = Request.GetBooleanQueryParameter("forceSave");
@ -94,6 +86,8 @@ namespace Radarr.Api.V3
}
_providerFactory.Update(providerDefinition);
return Accepted(providerResource.Id);
}
private TProviderDefinition GetDefinition(TProviderResource providerResource, bool includeWarnings = false, bool validate = true)
@ -108,12 +102,15 @@ namespace Radarr.Api.V3
return definition;
}
private void DeleteProvider(int id)
[RestDeleteById]
public object DeleteProvider(int id)
{
_providerFactory.Delete(id);
return new object();
}
private object GetTemplates()
[HttpGet("schema")]
public List<TProviderResource> GetTemplates()
{
var defaultDefinitions = _providerFactory.GetDefaultDefinitions().OrderBy(p => p.ImplementationName).ToList();
@ -134,7 +131,9 @@ namespace Radarr.Api.V3
return result;
}
private object Test(TProviderResource providerResource)
[SkipValidation(true, false)]
[HttpPost("test")]
public object Test([FromBody] TProviderResource providerResource)
{
var providerDefinition = GetDefinition(providerResource, true);
@ -143,7 +142,8 @@ namespace Radarr.Api.V3
return "{}";
}
private object TestAll()
[HttpPost("testall")]
public IActionResult TestAll()
{
var providerDefinitions = _providerFactory.All()
.Where(c => c.Settings.Validate().IsValid && c.Enable)
@ -161,19 +161,20 @@ namespace Radarr.Api.V3
});
}
return ResponseWithCode(result, result.Any(c => !c.IsValid) ? HttpStatusCode.BadRequest : HttpStatusCode.OK);
return result.Any(c => !c.IsValid) ? BadRequest(result) : Ok(result);
}
private object RequestAction(string action, TProviderResource providerResource)
[SkipValidation]
[HttpPost("action/{name}")]
public IActionResult RequestAction(string name, [FromBody] TProviderResource resource)
{
var providerDefinition = GetDefinition(providerResource, true, false);
var providerDefinition = GetDefinition(resource, true, false);
var query = ((IDictionary<string, object>)Request.Query.ToDictionary()).ToDictionary(k => k.Key, k => k.Value.ToString());
var query = Request.Query.ToDictionary(x => x.Key, x => x.Value.ToString());
var data = _providerFactory.RequestAction(providerDefinition, action, query);
Response resp = data.ToJson();
resp.ContentType = "application/json";
return resp;
var data = _providerFactory.RequestAction(providerDefinition, name, query);
return Content(data.ToJson(), "application/json");
}
protected virtual void Validate(TProviderDefinition definition, bool includeWarnings)

View File

@ -0,0 +1,54 @@
using System.Collections.Generic;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Qualities;
using Radarr.Http;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.Qualities
{
[V3ApiController]
public class QualityDefinitionController : RestController<QualityDefinitionResource>
{
private readonly IQualityDefinitionService _qualityDefinitionService;
public QualityDefinitionController(IQualityDefinitionService qualityDefinitionService)
{
_qualityDefinitionService = qualityDefinitionService;
}
[RestPutById]
public ActionResult<QualityDefinitionResource> Update(QualityDefinitionResource resource)
{
var model = resource.ToModel();
_qualityDefinitionService.Update(model);
return Accepted(model.Id);
}
public override QualityDefinitionResource GetResourceById(int id)
{
return _qualityDefinitionService.GetById(id).ToResource();
}
[HttpGet]
public List<QualityDefinitionResource> GetAll()
{
return _qualityDefinitionService.All().ToResource();
}
[HttpPut("update")]
public object UpdateMany([FromBody] List<QualityDefinitionResource> resource)
{
//Read from request
var qualityDefinitions = resource
.ToModel()
.ToList();
_qualityDefinitionService.UpdateMany(qualityDefinitions);
return Accepted(_qualityDefinitionService.All()
.ToResource());
}
}
}

View File

@ -1,54 +0,0 @@
using System.Collections.Generic;
using System.Linq;
using Nancy;
using NzbDrone.Core.Qualities;
using Radarr.Http;
using Radarr.Http.Extensions;
namespace Radarr.Api.V3.Qualities
{
public class QualityDefinitionModule : RadarrRestModule<QualityDefinitionResource>
{
private readonly IQualityDefinitionService _qualityDefinitionService;
public QualityDefinitionModule(IQualityDefinitionService qualityDefinitionService)
{
_qualityDefinitionService = qualityDefinitionService;
GetResourceAll = GetAll;
GetResourceById = GetById;
UpdateResource = Update;
Put("/update", d => UpdateMany());
}
private void Update(QualityDefinitionResource resource)
{
var model = resource.ToModel();
_qualityDefinitionService.Update(model);
}
private QualityDefinitionResource GetById(int id)
{
return _qualityDefinitionService.GetById(id).ToResource();
}
private List<QualityDefinitionResource> GetAll()
{
return _qualityDefinitionService.All().ToResource();
}
private object UpdateMany()
{
//Read from request
var qualityDefinitions = Request.Body.FromJson<List<QualityDefinitionResource>>()
.ToModel()
.ToList();
_qualityDefinitionService.UpdateMany(qualityDefinitions);
return ResponseWithCode(_qualityDefinitionService.All()
.ToResource(),
HttpStatusCode.Accepted);
}
}
}

View File

@ -0,0 +1,55 @@
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Download;
using NzbDrone.Core.Download.Pending;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Queue
{
[V3ApiController("queue")]
public class QueueActionController : Controller
{
private readonly IPendingReleaseService _pendingReleaseService;
private readonly IDownloadService _downloadService;
public QueueActionController(IPendingReleaseService pendingReleaseService,
IDownloadService downloadService)
{
_pendingReleaseService = pendingReleaseService;
_downloadService = downloadService;
}
[HttpPost("grab/{id:int}")]
public object Grab(int id)
{
var pendingRelease = _pendingReleaseService.FindPendingQueueItem(id);
if (pendingRelease == null)
{
throw new NotFoundException();
}
_downloadService.DownloadReport(pendingRelease.RemoteMovie);
return new object();
}
[HttpPost("grab/bulk")]
public object Grab([FromBody] QueueBulkResource resource)
{
foreach (var id in resource.Ids)
{
var pendingRelease = _pendingReleaseService.FindPendingQueueItem(id);
if (pendingRelease == null)
{
throw new NotFoundException();
}
_downloadService.DownloadReport(pendingRelease.RemoteMovie);
}
return new object();
}
}
}

View File

@ -1,179 +0,0 @@
using System.Collections.Generic;
using Nancy;
using NzbDrone.Core.Download;
using NzbDrone.Core.Download.Pending;
using NzbDrone.Core.Download.TrackedDownloads;
using NzbDrone.Core.Queue;
using Radarr.Http;
using Radarr.Http.Extensions;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Queue
{
public class QueueActionModule : RadarrRestModule<QueueResource>
{
private readonly IQueueService _queueService;
private readonly ITrackedDownloadService _trackedDownloadService;
private readonly IFailedDownloadService _failedDownloadService;
private readonly IIgnoredDownloadService _ignoredDownloadService;
private readonly IProvideDownloadClient _downloadClientProvider;
private readonly IPendingReleaseService _pendingReleaseService;
private readonly IDownloadService _downloadService;
public QueueActionModule(IQueueService queueService,
ITrackedDownloadService trackedDownloadService,
IFailedDownloadService failedDownloadService,
IIgnoredDownloadService ignoredDownloadService,
IProvideDownloadClient downloadClientProvider,
IPendingReleaseService pendingReleaseService,
IDownloadService downloadService)
{
_queueService = queueService;
_trackedDownloadService = trackedDownloadService;
_failedDownloadService = failedDownloadService;
_ignoredDownloadService = ignoredDownloadService;
_downloadClientProvider = downloadClientProvider;
_pendingReleaseService = pendingReleaseService;
_downloadService = downloadService;
Post(@"/grab/(?<id>[\d]{1,10})", x => Grab((int)x.Id));
Post("/grab/bulk", x => Grab());
Delete(@"/(?<id>[\d]{1,10})", x => Remove((int)x.Id));
Delete("/bulk", x => Remove());
}
private object Grab(int id)
{
var pendingRelease = _pendingReleaseService.FindPendingQueueItem(id);
if (pendingRelease == null)
{
throw new NotFoundException();
}
_downloadService.DownloadReport(pendingRelease.RemoteMovie);
return new object();
}
private object Grab()
{
var resource = Request.Body.FromJson<QueueBulkResource>();
foreach (var id in resource.Ids)
{
var pendingRelease = _pendingReleaseService.FindPendingQueueItem(id);
if (pendingRelease == null)
{
throw new NotFoundException();
}
_downloadService.DownloadReport(pendingRelease.RemoteMovie);
}
return new object();
}
private object Remove(int id)
{
var removeFromClient = Request.GetBooleanQueryParameter("removeFromClient", true);
var blocklist = Request.GetBooleanQueryParameter("blocklist");
var trackedDownload = Remove(id, removeFromClient, blocklist);
if (trackedDownload != null)
{
_trackedDownloadService.StopTracking(trackedDownload.DownloadItem.DownloadId);
}
return new object();
}
private object Remove()
{
var removeFromClient = Request.GetBooleanQueryParameter("removeFromClient", true);
var blocklist = Request.GetBooleanQueryParameter("blocklist");
var resource = Request.Body.FromJson<QueueBulkResource>();
var trackedDownloadIds = new List<string>();
foreach (var id in resource.Ids)
{
var trackedDownload = Remove(id, removeFromClient, blocklist);
if (trackedDownload != null)
{
trackedDownloadIds.Add(trackedDownload.DownloadItem.DownloadId);
}
}
_trackedDownloadService.StopTracking(trackedDownloadIds);
return new object();
}
private TrackedDownload Remove(int id, bool removeFromClient, bool blocklist)
{
var pendingRelease = _pendingReleaseService.FindPendingQueueItem(id);
if (pendingRelease != null)
{
_pendingReleaseService.RemovePendingQueueItems(pendingRelease.Id);
return null;
}
var trackedDownload = GetTrackedDownload(id);
if (trackedDownload == null)
{
throw new NotFoundException();
}
if (removeFromClient)
{
var downloadClient = _downloadClientProvider.Get(trackedDownload.DownloadClient);
if (downloadClient == null)
{
throw new BadRequestException();
}
downloadClient.RemoveItem(trackedDownload.DownloadItem, true);
}
if (blocklist)
{
_failedDownloadService.MarkAsFailed(trackedDownload.DownloadItem.DownloadId);
}
if (!removeFromClient && !blocklist && !_ignoredDownloadService.IgnoreDownload(trackedDownload))
{
return null;
}
return trackedDownload;
}
private TrackedDownload GetTrackedDownload(int queueId)
{
var queueItem = _queueService.Find(queueId);
if (queueItem == null)
{
throw new NotFoundException();
}
var trackedDownload = _trackedDownloadService.Find(queueItem.DownloadId);
if (trackedDownload == null)
{
throw new NotFoundException();
}
return trackedDownload;
}
}
}

View File

@ -1,9 +1,13 @@
using System;
using System.Collections.Generic;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Datastore;
using NzbDrone.Core.Datastore.Events;
using NzbDrone.Core.Download;
using NzbDrone.Core.Download.Pending;
using NzbDrone.Core.Download.TrackedDownloads;
using NzbDrone.Core.Languages;
using NzbDrone.Core.Messaging.Events;
using NzbDrone.Core.Profiles;
@ -12,37 +16,87 @@ using NzbDrone.Core.Queue;
using NzbDrone.SignalR;
using Radarr.Http;
using Radarr.Http.Extensions;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.Queue
{
public class QueueModule : RadarrRestModuleWithSignalR<QueueResource, NzbDrone.Core.Queue.Queue>,
[V3ApiController]
public class QueueController : RestControllerWithSignalR<QueueResource, NzbDrone.Core.Queue.Queue>,
IHandle<QueueUpdatedEvent>, IHandle<PendingReleasesUpdatedEvent>
{
private readonly IQueueService _queueService;
private readonly IPendingReleaseService _pendingReleaseService;
private readonly QualityModelComparer _qualityComparer;
private readonly ITrackedDownloadService _trackedDownloadService;
private readonly IFailedDownloadService _failedDownloadService;
private readonly IIgnoredDownloadService _ignoredDownloadService;
private readonly IProvideDownloadClient _downloadClientProvider;
public QueueModule(IBroadcastSignalRMessage broadcastSignalRMessage,
public QueueController(IBroadcastSignalRMessage broadcastSignalRMessage,
IQueueService queueService,
IPendingReleaseService pendingReleaseService,
ProfileService qualityProfileService)
ProfileService qualityProfileService,
ITrackedDownloadService trackedDownloadService,
IFailedDownloadService failedDownloadService,
IIgnoredDownloadService ignoredDownloadService,
IProvideDownloadClient downloadClientProvider)
: base(broadcastSignalRMessage)
{
_queueService = queueService;
_pendingReleaseService = pendingReleaseService;
GetResourcePaged = GetQueue;
_trackedDownloadService = trackedDownloadService;
_failedDownloadService = failedDownloadService;
_ignoredDownloadService = ignoredDownloadService;
_downloadClientProvider = downloadClientProvider;
_qualityComparer = new QualityModelComparer(qualityProfileService.GetDefaultProfile(string.Empty));
}
private PagingResource<QueueResource> GetQueue(PagingResource<QueueResource> pagingResource)
public override QueueResource GetResourceById(int id)
{
var pagingSpec = pagingResource.MapToPagingSpec<QueueResource, NzbDrone.Core.Queue.Queue>("timeleft", SortDirection.Ascending);
var includeUnknownMovieItems = Request.GetBooleanQueryParameter("includeUnknownMovieItems");
var includeMovie = Request.GetBooleanQueryParameter("includeMovie");
throw new NotImplementedException();
}
return ApplyToPage((spec) => GetQueue(spec, includeUnknownMovieItems), pagingSpec, (q) => MapToResource(q, includeMovie));
[RestDeleteById]
public void RemoveAction(int id, bool removeFromClient = true, bool blocklist = false)
{
var trackedDownload = Remove(id, removeFromClient, blocklist);
if (trackedDownload != null)
{
_trackedDownloadService.StopTracking(trackedDownload.DownloadItem.DownloadId);
}
}
[HttpDelete("bulk")]
public object RemoveMany([FromBody] QueueBulkResource resource, [FromQuery] bool removeFromClient = true, [FromQuery] bool blocklist = false)
{
var trackedDownloadIds = new List<string>();
foreach (var id in resource.Ids)
{
var trackedDownload = Remove(id, removeFromClient, blocklist);
if (trackedDownload != null)
{
trackedDownloadIds.Add(trackedDownload.DownloadItem.DownloadId);
}
}
_trackedDownloadService.StopTracking(trackedDownloadIds);
return new object();
}
[HttpGet]
public PagingResource<QueueResource> GetQueue(bool includeUnknownMovieItems = false, bool includeMovie = false)
{
var pagingResource = Request.ReadPagingResourceFromRequest<QueueResource>();
var pagingSpec = pagingResource.MapToPagingSpec<QueueResource, NzbDrone.Core.Queue.Queue>("timeleft", SortDirection.Ascending);
return pagingSpec.ApplyToPage((spec) => GetQueue(spec, includeUnknownMovieItems), (q) => MapToResource(q, includeMovie));
}
private PagingSpec<NzbDrone.Core.Queue.Queue> GetQueue(PagingSpec<NzbDrone.Core.Queue.Queue> pagingSpec, bool includeUnknownMovieItems)
@ -140,16 +194,83 @@ namespace Radarr.Api.V3.Queue
}
}
private TrackedDownload Remove(int id, bool removeFromClient, bool blocklist)
{
var pendingRelease = _pendingReleaseService.FindPendingQueueItem(id);
if (pendingRelease != null)
{
_pendingReleaseService.RemovePendingQueueItems(pendingRelease.Id);
return null;
}
var trackedDownload = GetTrackedDownload(id);
if (trackedDownload == null)
{
throw new NotFoundException();
}
if (removeFromClient)
{
var downloadClient = _downloadClientProvider.Get(trackedDownload.DownloadClient);
if (downloadClient == null)
{
throw new BadRequestException();
}
downloadClient.RemoveItem(trackedDownload.DownloadItem, true);
}
if (blocklist)
{
_failedDownloadService.MarkAsFailed(trackedDownload.DownloadItem.DownloadId);
}
if (!removeFromClient && !blocklist)
{
if (!_ignoredDownloadService.IgnoreDownload(trackedDownload))
{
return null;
}
}
return trackedDownload;
}
private TrackedDownload GetTrackedDownload(int queueId)
{
var queueItem = _queueService.Find(queueId);
if (queueItem == null)
{
throw new NotFoundException();
}
var trackedDownload = _trackedDownloadService.Find(queueItem.DownloadId);
if (trackedDownload == null)
{
throw new NotFoundException();
}
return trackedDownload;
}
private QueueResource MapToResource(NzbDrone.Core.Queue.Queue queueItem, bool includeMovie)
{
return queueItem.ToResource(includeMovie);
}
[NonAction]
public void Handle(QueueUpdatedEvent message)
{
BroadcastResourceChange(ModelAction.Sync);
}
[NonAction]
public void Handle(PendingReleasesUpdatedEvent message)
{
BroadcastResourceChange(ModelAction.Sync);

View File

@ -1,51 +1,58 @@
using System;
using System.Collections.Generic;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Datastore.Events;
using NzbDrone.Core.Download.Pending;
using NzbDrone.Core.Messaging.Events;
using NzbDrone.Core.Queue;
using NzbDrone.SignalR;
using Radarr.Http;
using Radarr.Http.Extensions;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Queue
{
public class QueueDetailsModule : RadarrRestModuleWithSignalR<QueueResource, NzbDrone.Core.Queue.Queue>,
[V3ApiController("queue/details")]
public class QueueDetailsController : RestControllerWithSignalR<QueueResource, NzbDrone.Core.Queue.Queue>,
IHandle<QueueUpdatedEvent>, IHandle<PendingReleasesUpdatedEvent>
{
private readonly IQueueService _queueService;
private readonly IPendingReleaseService _pendingReleaseService;
public QueueDetailsModule(IBroadcastSignalRMessage broadcastSignalRMessage, IQueueService queueService, IPendingReleaseService pendingReleaseService)
: base(broadcastSignalRMessage, "queue/details")
public QueueDetailsController(IBroadcastSignalRMessage broadcastSignalRMessage, IQueueService queueService, IPendingReleaseService pendingReleaseService)
: base(broadcastSignalRMessage)
{
_queueService = queueService;
_pendingReleaseService = pendingReleaseService;
GetResourceAll = GetQueue;
}
private List<QueueResource> GetQueue()
public override QueueResource GetResourceById(int id)
{
throw new NotImplementedException();
}
[HttpGet]
public List<QueueResource> GetQueue(int? movieId, bool includeMovie = false)
{
var includeMovie = Request.GetBooleanQueryParameter("includeMovie");
var queue = _queueService.GetQueue();
var pending = _pendingReleaseService.GetPendingQueue();
var fullQueue = queue.Concat(pending);
var movieIdQuery = Request.Query.MovieId;
if (movieIdQuery.HasValue)
if (movieId.HasValue)
{
return fullQueue.Where(q => q.Movie?.Id == (int)movieIdQuery).ToResource(includeMovie);
return fullQueue.Where(q => q.Movie?.Id == movieId.Value).ToResource(includeMovie);
}
return fullQueue.ToResource(includeMovie);
}
[NonAction]
public void Handle(QueueUpdatedEvent message)
{
BroadcastResourceChange(ModelAction.Sync);
}
[NonAction]
public void Handle(PendingReleasesUpdatedEvent message)
{
BroadcastResourceChange(ModelAction.Sync);

View File

@ -1,5 +1,6 @@
using System;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.TPL;
using NzbDrone.Core.Datastore.Events;
using NzbDrone.Core.Download.Pending;
@ -8,33 +9,34 @@ using NzbDrone.Core.Messaging.Events;
using NzbDrone.Core.Queue;
using NzbDrone.SignalR;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Queue
{
public class QueueStatusModule : RadarrRestModuleWithSignalR<QueueStatusResource, NzbDrone.Core.Queue.Queue>,
[V3ApiController("queue/status")]
public class QueueStatusController : RestControllerWithSignalR<QueueStatusResource, NzbDrone.Core.Queue.Queue>,
IHandle<QueueUpdatedEvent>, IHandle<PendingReleasesUpdatedEvent>
{
private readonly IQueueService _queueService;
private readonly IPendingReleaseService _pendingReleaseService;
private readonly Debouncer _broadcastDebounce;
public QueueStatusModule(IBroadcastSignalRMessage broadcastSignalRMessage, IQueueService queueService, IPendingReleaseService pendingReleaseService)
: base(broadcastSignalRMessage, "queue/status")
public QueueStatusController(IBroadcastSignalRMessage broadcastSignalRMessage, IQueueService queueService, IPendingReleaseService pendingReleaseService)
: base(broadcastSignalRMessage)
{
_queueService = queueService;
_pendingReleaseService = pendingReleaseService;
_broadcastDebounce = new Debouncer(BroadcastChange, TimeSpan.FromSeconds(5));
Get("/", x => GetQueueStatusResponse());
}
private object GetQueueStatusResponse()
public override QueueStatusResource GetResourceById(int id)
{
return GetQueueStatus();
throw new NotImplementedException();
}
private QueueStatusResource GetQueueStatus()
[HttpGet]
public QueueStatusResource GetQueueStatus()
{
_broadcastDebounce.Pause();
@ -62,11 +64,13 @@ namespace Radarr.Api.V3.Queue
BroadcastResourceChange(ModelAction.Updated, GetQueueStatus());
}
[NonAction]
public void Handle(QueueUpdatedEvent message)
{
_broadcastDebounce.Execute();
}
[NonAction]
public void Handle(PendingReleasesUpdatedEvent message)
{
_broadcastDebounce.Execute();

View File

@ -5,9 +5,6 @@
<ItemGroup>
<PackageReference Include="FluentValidation" Version="8.6.2" />
<PackageReference Include="Ical.Net" Version="4.1.11" />
<PackageReference Include="Nancy" Version="2.0.0" />
<PackageReference Include="Nancy.Authentication.Basic" Version="2.0.0" />
<PackageReference Include="Nancy.Authentication.Forms" Version="2.0.0" />
<PackageReference Include="NLog" Version="4.7.0" />
</ItemGroup>
<ItemGroup>

View File

@ -1,12 +0,0 @@
using Radarr.Http;
namespace Radarr.Api.V3
{
public abstract class RadarrV3FeedModule : RadarrModule
{
protected RadarrV3FeedModule(string resource)
: base("/feed/v3/" + resource.Trim('/'))
{
}
}
}

View File

@ -1,12 +0,0 @@
using Radarr.Http;
namespace Radarr.Api.V3
{
public abstract class RadarrV3Module : RadarrModule
{
protected RadarrV3Module(string resource)
: base("/api/v3/" + resource.Trim('/'))
{
}
}
}

View File

@ -1,27 +1,25 @@
using System.Collections.Generic;
using FluentValidation;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.RemotePathMappings;
using NzbDrone.Core.Validation.Paths;
using Radarr.Http;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.RemotePathMappings
{
public class RemotePathMappingModule : RadarrRestModule<RemotePathMappingResource>
[V3ApiController]
public class RemotePathMappingController : RestController<RemotePathMappingResource>
{
private readonly IRemotePathMappingService _remotePathMappingService;
public RemotePathMappingModule(IRemotePathMappingService remotePathMappingService,
public RemotePathMappingController(IRemotePathMappingService remotePathMappingService,
PathExistsValidator pathExistsValidator,
MappedNetworkDriveValidator mappedNetworkDriveValidator)
{
_remotePathMappingService = remotePathMappingService;
GetResourceAll = GetMappings;
GetResourceById = GetMappingById;
CreateResource = CreateMapping;
DeleteResource = DeleteMapping;
UpdateResource = UpdateMapping;
SharedValidator.RuleFor(c => c.Host)
.NotEmpty();
@ -36,33 +34,37 @@ namespace Radarr.Api.V3.RemotePathMappings
.SetValidator(pathExistsValidator);
}
private RemotePathMappingResource GetMappingById(int id)
public override RemotePathMappingResource GetResourceById(int id)
{
return _remotePathMappingService.Get(id).ToResource();
}
private int CreateMapping(RemotePathMappingResource resource)
[RestPostById]
public ActionResult<RemotePathMappingResource> CreateMapping(RemotePathMappingResource resource)
{
var model = resource.ToModel();
return _remotePathMappingService.Add(model).Id;
return Created(_remotePathMappingService.Add(model).Id);
}
private List<RemotePathMappingResource> GetMappings()
[HttpGet]
public List<RemotePathMappingResource> GetMappings()
{
return _remotePathMappingService.All().ToResource();
}
private void DeleteMapping(int id)
[RestDeleteById]
public void DeleteMapping(int id)
{
_remotePathMappingService.Remove(id);
}
private void UpdateMapping(RemotePathMappingResource resource)
[RestPutById]
public ActionResult<RemotePathMappingResource> UpdateMapping(RemotePathMappingResource resource)
{
var mapping = resource.ToModel();
_remotePathMappingService.Update(mapping);
return Accepted(_remotePathMappingService.Update(mapping));
}
}
}

View File

@ -1,25 +1,23 @@
using System.Collections.Generic;
using FluentValidation;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Restrictions;
using Radarr.Http;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.Restrictions
{
public class RestrictionModule : RadarrRestModule<RestrictionResource>
[V3ApiController]
public class RestrictionController : RestController<RestrictionResource>
{
private readonly IRestrictionService _restrictionService;
public RestrictionModule(IRestrictionService restrictionService)
public RestrictionController(IRestrictionService restrictionService)
{
_restrictionService = restrictionService;
GetResourceById = GetById;
GetResourceAll = GetAll;
CreateResource = Create;
UpdateResource = Update;
DeleteResource = DeleteRestriction;
SharedValidator.RuleFor(d => d).Custom((restriction, context) =>
{
if (restriction.Ignored.IsNullOrWhiteSpace() && restriction.Required.IsNullOrWhiteSpace())
@ -29,27 +27,32 @@ namespace Radarr.Api.V3.Restrictions
});
}
private RestrictionResource GetById(int id)
public override RestrictionResource GetResourceById(int id)
{
return _restrictionService.Get(id).ToResource();
}
private List<RestrictionResource> GetAll()
[HttpGet]
public List<RestrictionResource> GetAll()
{
return _restrictionService.All().ToResource();
}
private int Create(RestrictionResource resource)
[RestPostById]
public ActionResult<RestrictionResource> Create(RestrictionResource resource)
{
return _restrictionService.Add(resource.ToModel()).Id;
return Created(_restrictionService.Add(resource.ToModel()).Id);
}
private void Update(RestrictionResource resource)
[RestPutById]
public ActionResult<RestrictionResource> Update(RestrictionResource resource)
{
_restrictionService.Update(resource.ToModel());
return Accepted(resource.Id);
}
private void DeleteRestriction(int id)
[RestDeleteById]
public void DeleteRestriction(int id)
{
_restrictionService.Delete(id);
}

View File

@ -1,18 +1,22 @@
using System.Collections.Generic;
using FluentValidation;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.RootFolders;
using NzbDrone.Core.Validation.Paths;
using NzbDrone.SignalR;
using Radarr.Http;
using Radarr.Http.Extensions;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.RootFolders
{
public class RootFolderModule : RadarrRestModuleWithSignalR<RootFolderResource, RootFolder>
[V3ApiController]
public class RootFolderController : RestControllerWithSignalR<RootFolderResource, RootFolder>
{
private readonly IRootFolderService _rootFolderService;
public RootFolderModule(IRootFolderService rootFolderService,
public RootFolderController(IRootFolderService rootFolderService,
IBroadcastSignalRMessage signalRBroadcaster,
RootFolderValidator rootFolderValidator,
PathExistsValidator pathExistsValidator,
@ -25,11 +29,6 @@ namespace Radarr.Api.V3.RootFolders
{
_rootFolderService = rootFolderService;
GetResourceAll = GetRootFolders;
GetResourceById = GetRootFolder;
CreateResource = CreateRootFolder;
DeleteResource = DeleteFolder;
SharedValidator.RuleFor(c => c.Path)
.Cascade(CascadeMode.StopOnFirstFailure)
.IsValidPath()
@ -42,26 +41,29 @@ namespace Radarr.Api.V3.RootFolders
.SetValidator(folderWritableValidator);
}
private RootFolderResource GetRootFolder(int id)
public override RootFolderResource GetResourceById(int id)
{
var timeout = Context?.Request?.GetBooleanQueryParameter("timeout", true) ?? true;
var timeout = Request?.GetBooleanQueryParameter("timeout", true) ?? true;
return _rootFolderService.Get(id, timeout).ToResource();
}
private int CreateRootFolder(RootFolderResource rootFolderResource)
[RestPostById]
public ActionResult<RootFolderResource> CreateRootFolder(RootFolderResource rootFolderResource)
{
var model = rootFolderResource.ToModel();
return _rootFolderService.Add(model).Id;
return Created(_rootFolderService.Add(model).Id);
}
private List<RootFolderResource> GetRootFolders()
[HttpGet]
public List<RootFolderResource> GetRootFolders()
{
return _rootFolderService.AllWithUnmappedFolders().ToResource();
}
private void DeleteFolder(int id)
[RestDeleteById]
public void DeleteFolder(int id)
{
_rootFolderService.Remove(id);
}

View File

@ -1,6 +1,7 @@
using System.Collections.Generic;
using System.IO;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Crypto;
using NzbDrone.Common.Disk;
using NzbDrone.Common.EnvironmentInfo;
@ -8,10 +9,12 @@ using NzbDrone.Common.Extensions;
using NzbDrone.Core.Backup;
using Radarr.Http;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.System.Backup
{
public class BackupModule : RadarrRestModule<BackupResource>
[V3ApiController("system/backup")]
public class BackupController : Controller
{
private readonly IBackupService _backupService;
private readonly IAppFolderInfo _appFolderInfo;
@ -19,21 +22,16 @@ namespace Radarr.Api.V3.System.Backup
private static readonly List<string> ValidExtensions = new List<string> { ".zip", ".db", ".xml" };
public BackupModule(IBackupService backupService,
public BackupController(IBackupService backupService,
IAppFolderInfo appFolderInfo,
IDiskProvider diskProvider)
: base("system/backup")
{
_backupService = backupService;
_appFolderInfo = appFolderInfo;
_diskProvider = diskProvider;
GetResourceAll = GetBackupFiles;
DeleteResource = DeleteBackup;
Post(@"/restore/(?<id>[\d]{1,10})", x => Restore((int)x.Id));
Post("/restore/upload", x => UploadAndRestore());
}
[HttpGet]
public List<BackupResource> GetBackupFiles()
{
var backups = _backupService.GetBackups();
@ -50,7 +48,8 @@ namespace Radarr.Api.V3.System.Backup
.ToList();
}
private void DeleteBackup(int id)
[RestDeleteById]
public void DeleteBackup(int id)
{
var backup = GetBackup(id);
var path = GetBackupPath(backup);
@ -63,6 +62,7 @@ namespace Radarr.Api.V3.System.Backup
_diskProvider.DeleteFile(path);
}
[HttpPost("restore/{id:int}")]
public object Restore(int id)
{
var backup = GetBackup(id);
@ -82,9 +82,10 @@ namespace Radarr.Api.V3.System.Backup
};
}
[HttpPost("restore/upload")]
public object UploadAndRestore()
{
var files = Context.Request.Files.ToList();
var files = Request.Form.Files;
if (files.Empty())
{
@ -92,7 +93,7 @@ namespace Radarr.Api.V3.System.Backup
}
var file = files.First();
var extension = Path.GetExtension(file.Name);
var extension = Path.GetExtension(file.FileName);
if (!ValidExtensions.Contains(extension))
{
@ -101,7 +102,7 @@ namespace Radarr.Api.V3.System.Backup
var path = Path.Combine(_appFolderInfo.TempFolder, $"radarr_backup_restore{extension}");
_diskProvider.SaveStream(file.Value, path);
_diskProvider.SaveStream(file.OpenReadStream(), path);
_backupService.Restore(path);
// Cleanup restored file

View File

@ -1,52 +1,60 @@
using System.IO;
using System.Threading.Tasks;
using Nancy.Routing;
using Microsoft.AspNetCore.Mvc;
using Microsoft.AspNetCore.Routing;
using Microsoft.AspNetCore.Routing.Internal;
using NzbDrone.Common.EnvironmentInfo;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Configuration;
using NzbDrone.Core.Datastore;
using NzbDrone.Core.Lifecycle;
using Radarr.Http;
using Radarr.Http.Validation;
namespace Radarr.Api.V3.System
{
public class SystemModule : RadarrV3Module
[V3ApiController]
public class SystemController : Controller
{
private readonly IAppFolderInfo _appFolderInfo;
private readonly IRuntimeInfo _runtimeInfo;
private readonly IPlatformInfo _platformInfo;
private readonly IOsInfo _osInfo;
private readonly IRouteCacheProvider _routeCacheProvider;
private readonly IConfigFileProvider _configFileProvider;
private readonly IMainDatabase _database;
private readonly ILifecycleService _lifecycleService;
private readonly IDeploymentInfoProvider _deploymentInfoProvider;
private readonly EndpointDataSource _endpointData;
private readonly DfaGraphWriter _graphWriter;
private readonly DuplicateEndpointDetector _detector;
public SystemModule(IAppFolderInfo appFolderInfo,
IRuntimeInfo runtimeInfo,
IPlatformInfo platformInfo,
IOsInfo osInfo,
IRouteCacheProvider routeCacheProvider,
IConfigFileProvider configFileProvider,
IMainDatabase database,
ILifecycleService lifecycleService,
IDeploymentInfoProvider deploymentInfoProvider)
: base("system")
public SystemController(IAppFolderInfo appFolderInfo,
IRuntimeInfo runtimeInfo,
IPlatformInfo platformInfo,
IOsInfo osInfo,
IConfigFileProvider configFileProvider,
IMainDatabase database,
ILifecycleService lifecycleService,
IDeploymentInfoProvider deploymentInfoProvider,
EndpointDataSource endpoints,
DfaGraphWriter graphWriter,
DuplicateEndpointDetector detector)
{
_appFolderInfo = appFolderInfo;
_runtimeInfo = runtimeInfo;
_platformInfo = platformInfo;
_osInfo = osInfo;
_routeCacheProvider = routeCacheProvider;
_configFileProvider = configFileProvider;
_database = database;
_lifecycleService = lifecycleService;
_deploymentInfoProvider = deploymentInfoProvider;
Get("/status", x => GetStatus());
Get("/routes", x => GetRoutes());
Post("/shutdown", x => Shutdown());
Post("/restart", x => Restart());
_endpointData = endpoints;
_graphWriter = graphWriter;
_detector = detector;
}
private object GetStatus()
[HttpGet("status")]
public object GetStatus()
{
return new
{
@ -81,18 +89,32 @@ namespace Radarr.Api.V3.System
};
}
private object GetRoutes()
[HttpGet("routes")]
public IActionResult GetRoutes()
{
return _routeCacheProvider.GetCache().Values;
using (var sw = new StringWriter())
{
_graphWriter.Write(_endpointData, sw);
var graph = sw.ToString();
return Content(graph, "text/plain");
}
}
private object Shutdown()
[HttpGet("routes/duplicate")]
public object DuplicateRoutes()
{
return _detector.GetDuplicateEndpoints(_endpointData);
}
[HttpPost("shutdown")]
public object Shutdown()
{
Task.Factory.StartNew(() => _lifecycleService.Shutdown());
return new { ShuttingDown = true };
}
private object Restart()
[HttpPost("restart")]
public object Restart()
{
Task.Factory.StartNew(() => _lifecycleService.Restart());
return new { Restarting = true };

View File

@ -1,27 +1,29 @@
using System.Collections.Generic;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Datastore.Events;
using NzbDrone.Core.Jobs;
using NzbDrone.Core.Messaging.Events;
using NzbDrone.SignalR;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.System.Tasks
{
public class TaskModule : RadarrRestModuleWithSignalR<TaskResource, ScheduledTask>, IHandle<CommandExecutedEvent>
[V3ApiController("system/task")]
public class TaskController : RestControllerWithSignalR<TaskResource, ScheduledTask>, IHandle<CommandExecutedEvent>
{
private readonly ITaskManager _taskManager;
public TaskModule(ITaskManager taskManager, IBroadcastSignalRMessage broadcastSignalRMessage)
: base(broadcastSignalRMessage, "system/task")
public TaskController(ITaskManager taskManager, IBroadcastSignalRMessage broadcastSignalRMessage)
: base(broadcastSignalRMessage)
{
_taskManager = taskManager;
GetResourceAll = GetAll;
GetResourceById = GetTask;
}
private List<TaskResource> GetAll()
[HttpGet]
public List<TaskResource> GetAll()
{
return _taskManager.GetAll()
.Select(ConvertToResource)
@ -29,7 +31,7 @@ namespace Radarr.Api.V3.System.Tasks
.ToList();
}
private TaskResource GetTask(int id)
public override TaskResource GetResourceById(int id)
{
var task = _taskManager.GetAll()
.SingleOrDefault(t => t.Id == id);
@ -58,6 +60,7 @@ namespace Radarr.Api.V3.System.Tasks
};
}
[NonAction]
public void Handle(CommandExecutedEvent message)
{
BroadcastResourceChange(ModelAction.Sync);

View File

@ -0,0 +1,61 @@
using System.Collections.Generic;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Datastore.Events;
using NzbDrone.Core.Messaging.Events;
using NzbDrone.Core.Tags;
using NzbDrone.SignalR;
using Radarr.Http;
using Radarr.Http.REST;
using Radarr.Http.REST.Attributes;
namespace Radarr.Api.V3.Tags
{
[V3ApiController]
public class TagController : RestControllerWithSignalR<TagResource, Tag>, IHandle<TagsUpdatedEvent>
{
private readonly ITagService _tagService;
public TagController(IBroadcastSignalRMessage signalRBroadcaster,
ITagService tagService)
: base(signalRBroadcaster)
{
_tagService = tagService;
}
public override TagResource GetResourceById(int id)
{
return _tagService.GetTag(id).ToResource();
}
[HttpGet]
public List<TagResource> GetAll()
{
return _tagService.All().ToResource();
}
[RestPostById]
public ActionResult<TagResource> Create(TagResource resource)
{
return Created(_tagService.Add(resource.ToModel()).Id);
}
[RestPutById]
public ActionResult<TagResource> Update(TagResource resource)
{
_tagService.Update(resource.ToModel());
return Accepted(resource.Id);
}
[RestDeleteById]
public void DeleteTag(int id)
{
_tagService.Delete(id);
}
[NonAction]
public void Handle(TagsUpdatedEvent message)
{
BroadcastResourceChange(ModelAction.Sync);
}
}
}

View File

@ -1,28 +1,28 @@
using System.Collections.Generic;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Core.Tags;
using Radarr.Http;
using Radarr.Http.REST;
namespace Radarr.Api.V3.Tags
{
public class TagDetailsModule : RadarrRestModule<TagDetailsResource>
[V3ApiController("tag/detail")]
public class TagDetailsController : RestController<TagDetailsResource>
{
private readonly ITagService _tagService;
public TagDetailsModule(ITagService tagService)
: base("/tag/detail")
public TagDetailsController(ITagService tagService)
{
_tagService = tagService;
GetResourceById = GetById;
GetResourceAll = GetAll;
}
private TagDetailsResource GetById(int id)
public override TagDetailsResource GetResourceById(int id)
{
return _tagService.Details(id).ToResource();
}
private List<TagDetailsResource> GetAll()
[HttpGet]
public List<TagDetailsResource> GetAll()
{
return _tagService.Details().ToResource();
}

View File

@ -1,57 +0,0 @@
using System.Collections.Generic;
using NzbDrone.Core.Datastore.Events;
using NzbDrone.Core.Messaging.Events;
using NzbDrone.Core.Tags;
using NzbDrone.SignalR;
using Radarr.Http;
namespace Radarr.Api.V3.Tags
{
public class TagModule : RadarrRestModuleWithSignalR<TagResource, Tag>, IHandle<TagsUpdatedEvent>
{
private readonly ITagService _tagService;
public TagModule(IBroadcastSignalRMessage signalRBroadcaster,
ITagService tagService)
: base(signalRBroadcaster)
{
_tagService = tagService;
GetResourceById = GetById;
GetResourceAll = GetAll;
CreateResource = Create;
UpdateResource = Update;
DeleteResource = DeleteTag;
}
private TagResource GetById(int id)
{
return _tagService.GetTag(id).ToResource();
}
private List<TagResource> GetAll()
{
return _tagService.All().ToResource();
}
private int Create(TagResource resource)
{
return _tagService.Add(resource.ToModel()).Id;
}
private void Update(TagResource resource)
{
_tagService.Update(resource.ToModel());
}
private void DeleteTag(int id)
{
_tagService.Delete(id);
}
public void Handle(TagsUpdatedEvent message)
{
BroadcastResourceChange(ModelAction.Sync);
}
}
}

View File

@ -1,5 +1,6 @@
using System.Collections.Generic;
using System.Linq;
using Microsoft.AspNetCore.Mvc;
using NzbDrone.Common.EnvironmentInfo;
using NzbDrone.Common.Extensions;
using NzbDrone.Core.Update;
@ -8,19 +9,20 @@ using Radarr.Http;
namespace Radarr.Api.V3.Update
{
public class UpdateModule : RadarrRestModule<UpdateResource>
[V3ApiController]
public class UpdateController : Controller
{
private readonly IRecentUpdateProvider _recentUpdateProvider;
private readonly IUpdateHistoryService _updateHistoryService;
public UpdateModule(IRecentUpdateProvider recentUpdateProvider, IUpdateHistoryService updateHistoryService)
public UpdateController(IRecentUpdateProvider recentUpdateProvider, IUpdateHistoryService updateHistoryService)
{
_recentUpdateProvider = recentUpdateProvider;
_updateHistoryService = updateHistoryService;
GetResourceAll = GetRecentUpdates;
}
private List<UpdateResource> GetRecentUpdates()
[HttpGet]
public List<UpdateResource> GetRecentUpdates()
{
var resources = _recentUpdateProvider.GetRecentUpdatePackages()
.OrderByDescending(u => u.Version)

View File

@ -0,0 +1,89 @@
using System.Collections.Generic;
using System.Linq;
using System.Security.Claims;
using System.Text.Encodings.Web;
using System.Threading.Tasks;
using Microsoft.AspNetCore.Authentication;
using Microsoft.Extensions.Logging;
using Microsoft.Extensions.Options;
namespace Radarr.Http.Authentication
{
public class ApiKeyAuthenticationOptions : AuthenticationSchemeOptions
{
public const string DefaultScheme = "API Key";
public string Scheme => DefaultScheme;
public string AuthenticationType = DefaultScheme;
public string HeaderName { get; set; }
public string QueryName { get; set; }
public string ApiKey { get; set; }
}
public class ApiKeyAuthenticationHandler : AuthenticationHandler<ApiKeyAuthenticationOptions>
{
public ApiKeyAuthenticationHandler(IOptionsMonitor<ApiKeyAuthenticationOptions> options,
ILoggerFactory logger,
UrlEncoder encoder,
ISystemClock clock)
: base(options, logger, encoder, clock)
{
}
private string ParseApiKey()
{
// Try query parameter
if (Request.Query.TryGetValue(Options.QueryName, out var value))
{
return value.FirstOrDefault();
}
// No ApiKey query parameter found try headers
if (Request.Headers.TryGetValue(Options.HeaderName, out var headerValue))
{
return headerValue.FirstOrDefault();
}
return Request.Headers["Authorization"].FirstOrDefault()?.Replace("Bearer ", "");
}
protected override Task<AuthenticateResult> HandleAuthenticateAsync()
{
var providedApiKey = ParseApiKey();
if (string.IsNullOrWhiteSpace(providedApiKey))
{
return Task.FromResult(AuthenticateResult.NoResult());
}
if (Options.ApiKey == providedApiKey)
{
var claims = new List<Claim>
{
new Claim("ApiKey", "true")
};
var identity = new ClaimsIdentity(claims, Options.AuthenticationType);
var identities = new List<ClaimsIdentity> { identity };
var principal = new ClaimsPrincipal(identities);
var ticket = new AuthenticationTicket(principal, Options.Scheme);
return Task.FromResult(AuthenticateResult.Success(ticket));
}
return Task.FromResult(AuthenticateResult.NoResult());
}
protected override Task HandleChallengeAsync(AuthenticationProperties properties)
{
Response.StatusCode = 401;
return Task.CompletedTask;
}
protected override Task HandleForbiddenAsync(AuthenticationProperties properties)
{
Response.StatusCode = 403;
return Task.CompletedTask;
}
}
}

Some files were not shown because too many files have changed in this diff Show More