基于 ABP vNext + CQRS + MediatR 构建高可用与高性能微服务系统:从架构设计到落地实战

🧠 基于 ABP vNext + CQRS + MediatR 构建高可用与高性能微服务系统:从架构设计到落地实战


目录

  • [🧠 基于 ABP vNext + CQRS + MediatR 构建高可用与高性能微服务系统:从架构设计到落地实战](#🧠 基于 ABP vNext + CQRS + MediatR 构建高可用与高性能微服务系统:从架构设计到落地实战)
    • [🧰 模块结构概览](#🧰 模块结构概览)
    • [📦 各模块注册代码示例](#📦 各模块注册代码示例)
    • [🧱 架构图 & 概念说明](#🧱 架构图 & 概念说明)
    • [✍️ 核心代码实践](#✍️ 核心代码实践)
      • [1. 聚合根 & 仓储接口](#1. 聚合根 & 仓储接口)
      • [2. CacheKeys 常量](#2. CacheKeys 常量)
      • [3. 命令 + 验证器 + 幂等处理](#3. 命令 + 验证器 + 幂等处理)
      • [4. Pipeline 行为示意图](#4. Pipeline 行为示意图)
      • [5. ValidationBehavior + LoggingBehavior](#5. ValidationBehavior + LoggingBehavior)
      • [6. 查询缓存 + 布隆过滤器](#6. 查询缓存 + 布隆过滤器)
      • 部署架构示意图
    • [🧪 自动化测试示例(Testcontainers)](#🧪 自动化测试示例(Testcontainers))
    • [📦 Docker Compose](#📦 Docker Compose)

🧰 模块结构概览

复制代码
Abp.CqrsDemo
├── src
│   ├── Abp.CqrsDemo.Domain
│   ├── Abp.CqrsDemo.Application
│   ├── Abp.CqrsDemo.HttpApi
│   └── Abp.CqrsDemo.DbMigrator
└── tests
    └── Abp.CqrsDemo.Tests
  • Domain:实体、聚合根、领域事件、仓储接口
  • Application:命令、查询、MediatR 处理器、DTO、Pipeline Behaviors、CacheKeys
  • HttpApi:控制器、外部配置绑定
  • DbMigrator:数据库初始化与迁移工具

📦 各模块注册代码示例

DomainModule

csharp 复制代码
[DependsOn(typeof(AbpDddDomainModule))]
public class CqrsDemoDomainModule : AbpModule
{
}

ApplicationModule

csharp 复制代码
[DependsOn(typeof(CqrsDemoDomainModule))]
public class CqrsDemoApplicationModule : AbpModule
{
    public override void ConfigureServices(ServiceConfigurationContext context)
    {
        // CQRS & Validation
        context.Services.AddMediatR(typeof(CqrsDemoApplicationModule).Assembly);
        context.Services.AddValidatorsFromAssembly(typeof(CqrsDemoApplicationModule).Assembly);

        // Pipeline Behaviors
        context.Services.AddTransient(typeof(IPipelineBehavior<,>), typeof(ValidationBehavior<,>));
        context.Services.AddTransient(typeof(IPipelineBehavior<,>), typeof(LoggingBehavior<,>));

        // 分布式缓存注册(Application 层即可依赖)
        context.Services.AddDistributedCache<OrderDto>();
    }
}

HttpApiModule

csharp 复制代码
[DependsOn(typeof(CqrsDemoApplicationModule))]
public class CqrsDemoHttpApiModule : AbpModule
{
    public override void ConfigureServices(ServiceConfigurationContext context)
    {
        var configuration = context.Services.GetConfiguration();

        // Redis 连接与缓存
        context.Services.AddStackExchangeRedisCache(options =>
        {
            options.Configuration = configuration["Redis:Connection"];
        });

        // 控制器托管
        context.Services.AddControllers();
    }
}

DbMigratorModule

csharp 复制代码
[DependsOn(typeof(AbpEntityFrameworkCoreModule))]
public class CqrsDemoDbMigratorModule : AbpModule
{
    public override void ConfigureServices(ServiceConfigurationContext context)
    {
        context.Services.AddAbpDbContext<CqrsDemoDbContext>(options =>
        {
            options.AddDefaultRepositories(includeAllEntities: true);
        });

        // 设置 EF Core 数据库提供者
        Configure<AbpDbContextOptions>(options =>
        {
            options.UseSqlServer(); // 或 UseNpgsql()
        });
    }
}

🧱 架构图 & 概念说明

Command/Query API 控制器 MediatR Dispatcher CommandHandler QueryHandler EFCore 写库 Redis 查询缓存

  • 命令 负责状态更改
  • 查询 可接入 Redis 或 读库
  • Pipeline:Validation → Logging → Handler

✍️ 核心代码实践

1. 聚合根 & 仓储接口

csharp 复制代码
public class Order : AggregateRoot<Guid>
{
    public string ProductId { get; private set; }
    public int Quantity { get; private set; }

    protected Order() { } // EF Core 兼容

    public Order(Guid id, string productId, int quantity)
    {
        Id = id;
        ProductId = productId;
        Quantity = quantity;
    }

    // 业务规则示例
    public void ChangeQuantity(int newQty)
    {
        if (newQty <= 0) throw new BusinessException("Quantity must be positive");
        Quantity = newQty;
    }
}

public interface IOrderRepository : IRepository<Order, Guid>
{
}

2. CacheKeys 常量

csharp 复制代码
public static class CacheKeys
{
    public const string OrderById = "order:{0}";
}

3. 命令 + 验证器 + 幂等处理

csharp 复制代码
public record CreateOrderCommand(Guid OrderId, string ProductId, int Quantity) : IRequest<Guid>;

public class CreateOrderValidator : AbstractValidator<CreateOrderCommand>
{
    public CreateOrderValidator()
    {
        RuleFor(x => x.ProductId).NotEmpty();
        RuleFor(x => x.Quantity).GreaterThan(0);
    }
}

public class CreateOrderHandler : IRequestHandler<CreateOrderCommand, Guid>
{
    private readonly IOrderRepository _repo;
    private readonly IDistributedIdempotencyService _idempotency;

    public CreateOrderHandler(IOrderRepository repo, IDistributedIdempotencyService idempotency)
    {
        _repo = repo;
        _idempotency = idempotency;
    }

    public async Task<Guid> Handle(CreateOrderCommand request, CancellationToken ct)
    {
        return await _idempotency.ExecuteAsync(request.OrderId.ToString(), async () =>
        {
            var order = new Order(request.OrderId, request.ProductId, request.Quantity);
            await _repo.InsertAsync(order, cancellationToken: ct);
            return order.Id;
        });
    }
}

4. Pipeline 行为示意图

Client PipelineBehaviors Handler Send Request ValidationBehavior LoggingBehavior Handle Command/Query Return Response Client PipelineBehaviors Handler

5. ValidationBehavior + LoggingBehavior

csharp 复制代码
public class ValidationBehavior<TRequest, TResponse> : IPipelineBehavior<TRequest, TResponse>
    where TRequest : notnull
{
    private readonly IEnumerable<IValidator<TRequest>> _validators;
    public ValidationBehavior(IEnumerable<IValidator<TRequest>> validators) => _validators = validators;

    public async Task<TResponse> Handle(TRequest request, RequestHandlerDelegate<TResponse> next, CancellationToken ct)
    {
        var context = new ValidationContext<TRequest>(request);
        var results = await Task.WhenAll(
            _validators.Select(v => v.ValidateAsync(context, ct))
        );
        var failures = results.SelectMany(r => r.Errors).Where(f => f != null).ToList();
        if (failures.Any()) throw new ValidationException(failures);
        return await next();
    }
}

public class LoggingBehavior<TRequest, TResponse> : IPipelineBehavior<TRequest, TResponse>
{
    private readonly ILogger<LoggingBehavior<TRequest, TResponse>> _logger;
    public LoggingBehavior(ILogger<LoggingBehavior<TRequest, TResponse>> logger) => _logger = logger;

    public async Task<TResponse> Handle(TRequest request, RequestHandlerDelegate<TResponse> next, CancellationToken ct)
    {
        _logger.LogInformation("Handling {Request} with payload: {@Payload}", typeof(TRequest).Name, request);
        var sw = Stopwatch.StartNew();
        var response = await next();
        sw.Stop();
        _logger.LogInformation("Handled {Request} in {Elapsed}ms with response: {@Response}", typeof(TRequest).Name, sw.ElapsedMilliseconds, response);
        return response;
    }
}

6. 查询缓存 + 布隆过滤器

csharp 复制代码
public class GetOrderByIdHandler : IRequestHandler<GetOrderByIdQuery, OrderDto>
{
    private readonly IOrderRepository _repo;
    private readonly IDistributedCache<OrderDto> _cache;
    private readonly IBloomFilter _bloomFilter;

    public GetOrderByIdHandler(
        IOrderRepository repo,
        IDistributedCache<OrderDto> cache,
        IBloomFilter bloomFilter)
    {
        _repo = repo;
        _cache = cache;
        _bloomFilter = bloomFilter;
    }

    public async Task<OrderDto> Handle(GetOrderByIdQuery request, CancellationToken ct)
    {
        if (!_bloomFilter.Contains(request.OrderId))
            throw new EntityNotFoundException(typeof(Order), request.OrderId);

        var cacheKey = string.Format(CacheKeys.OrderById, request.OrderId);
        return await _cache.GetOrAddAsync(
            cacheKey,
            async () =>
            {
                var order = await _repo.FindAsync(request.OrderId, ct);
                if (order == null) throw new EntityNotFoundException(typeof(Order), request.OrderId);
                return new OrderDto(order.Id, order.ProductId, order.Quantity);
            },
            options =>
            {
                options.SlidingExpiration = TimeSpan.FromMinutes(5);
                options.AbsoluteExpirationRelativeToNow = TimeSpan.FromHours(1);
            }
        );
    }
}

```markdown

---

## 🚀 部署与运行(Program.cs)

```csharp
var builder = WebApplication.CreateBuilder(args);
var config = builder.Configuration;

// 外部化配置
builder.Host.ConfigureAppConfiguration((ctx, cfg) =>
{
    cfg.AddJsonFile("appsettings.json", optional: false, reloadOnChange: true)
       .AddEnvironmentVariables();
});

// EF Core & DbContext
builder.Services.AddAbpDbContext<CqrsDemoDbContext>(options =>
{
    options.AddDefaultRepositories();
});
builder.Services.Configure<AbpDbContextOptions>(options =>
    options.UseSqlServer(config.GetConnectionString("Default")));

// Redis 缓存 & 布隆过滤器
builder.Services.AddStackExchangeRedisCache(opts =>
    opts.Configuration = config["Redis:Connection"]);
builder.Services.AddSingleton<IBloomFilter>(_ =>
    new BloomFilter(expectedItemCount: 10000, falsePositiveRate: 0.01));

// Health Checks
builder.Services.AddHealthChecks()
    .AddDbContextCheck<CqrsDemoDbContext>("Database")
    .AddRedis(config["Redis:Connection"], name: "Redis");

// Polly HTTP 客户端
builder.Services.AddHttpClient("order")
    .AddTransientHttpErrorPolicy(p => p.WaitAndRetryAsync(3, i => TimeSpan.FromSeconds(Math.Pow(2, i))))
    .AddTransientHttpErrorPolicy(p => p.CircuitBreakerAsync(5, TimeSpan.FromSeconds(30)));

var app = builder.Build();
app.MapHealthChecks("/health/live", new HealthCheckOptions { Predicate = _ => false });
app.MapHealthChecks("/health/ready");

app.MapControllers();
app.Run();

部署架构示意图

HTTP Route Read/Write Cache Client Ingress/Nginx API Pods PostgreSQL Redis


🧪 自动化测试示例(Testcontainers)

csharp 复制代码
using DotNet.Testcontainers.Builders;
using DotNet.Testcontainers.Containers;

public class CustomWebAppFactory : WebApplicationFactory<Program>, IAsyncLifetime
{
    private readonly PostgreSqlTestcontainer _postgres;

    public CustomWebAppFactory()
    {
        _postgres = new TestcontainersBuilder<PostgreSqlTestcontainer>()
            .WithDatabase(new PostgreSqlTestcontainerConfiguration
            {
                Database = "demo",
                Username = "sa",
                Password = "sa"
            }).Build();
    }

    public async Task InitializeAsync() => await _postgres.StartAsync();
    public async Task DisposeAsync() => await _postgres.DisposeAsync();

    protected override void ConfigureWebHost(IWebHostBuilder builder)
    {
        builder.ConfigureAppConfiguration((ctx, cfg) =>
        {
            cfg.AddInMemoryCollection(new Dictionary<string, string>
            {
                ["ConnectionStrings:Default"] = _postgres.ConnectionString
            });
        });
    }
}

public class OrderApiTests : IClassFixture<CustomWebAppFactory>
{
    private readonly HttpClient _client;
    public OrderApiTests(CustomWebAppFactory factory) => _client = factory.CreateClient();

    [Fact]
    public async Task Should_Create_Order_Successfully()
    {
        var command = new { orderId = Guid.NewGuid(), productId = "A001", quantity = 1 };
        var response = await _client.PostAsJsonAsync("/api/orders", command);
        response.EnsureSuccessStatusCode();
    }
}

测试流程图

Test 初始化 启动 Postgres 容器 配置 WebHost 运行集成测试 销毁容器


📦 Docker Compose

yaml 复制代码
version: "3.9"
services:
  api:
    build: .
    ports:
      - "5000:80"
  db:
    image: postgres
    environment:
      POSTGRES_DB: demo
      POSTGRES_USER: sa
      POSTGRES_PASSWORD: sa
  redis:
    image: redis

相关推荐
Chicheng_MA4 小时前
LuCI 工作架构介绍
架构·luci
遥远_7 小时前
Java微服务无损发布生产案例
java·spring·微服务·优雅停机·java微服务无损发布
kkkkk0211067 小时前
黑马微服务保险(一)
笔记·微服务·架构
遥远_7 小时前
Spring Boot微服务健康检测:保障系统稳定性的关键实践
spring boot·微服务·1024程序员节·健康检测
Tony Bai7 小时前
【Go 网络编程全解】13 从 HTTP/1.1 到 gRPC:Web API 与微服务的演进
开发语言·网络·http·微服务·golang
青鱼入云7 小时前
TraceId如何在Spring-Cloud微服务的REST调用中传递
微服务·架构·链路追踪
机灵猫8 小时前
微服务中的服务熔断、降级与限流
java·数据库·微服务
追逐时光者10 小时前
全面的 C#/.NET 图表构建解决方案,助力快速实现图表开发需求!
后端·.net
周杰伦_Jay11 小时前
【常用设计模式全解析】创建型模式(聚焦对象创建机制)、结构型模式(优化类与对象的组合关系)、行为型模式(规范对象间的交互行为)
设计模式·架构·开源·交互·1024程序员节
丈剑走天涯12 小时前
k8s etcd服务安装维护
云原生·etcd·devops·1024程序员节