使用ABP SignalR重构消息服务(二)

上篇使用ABP SignalR重构消息服务(一)主要讲的是SignalR的基础知识和前端如何使用SignalR,这段时间也是落实方案设计。这篇我主要讲解SignalR源码(最近我手头工作比较忙@蟹老板)。

SignalR源码分析(原地址,原地址已经停止维护了合并到了AspNetCore

使用SignalR我们主要是添加services.AddSignalR();,添加ChatHub类继承我们的Hub ,然后管道注入endpoints.MapHub<ChatHub>("/ChatHub");
通过services.AddSignalR()可以看到使用的类是SignalRDependencyInjectionExtensions
通过Hub类可以看到程序集是Microsoft.AspNetCore.SignalR.Core
通过MapHub<ChatHub>可以看到使用的类是HubEndpointRouteBuilderExtensions

SignalR服务注册

我们先分析services.AddSignalR()注入做了什么准备

这里我们要讲一个东西Microsoft.AspNetCore.SignalR.Core类库有一个SignalRDependencyInjectionExtensions
Microsoft.AspNetCore.SignalR类库也存在一个SignalRDependencyInjectionExtensions

Microsoft.AspNetCore.SignalR类库中的SignalRDependencyInjectionExtensions解读

public static class SignalRDependencyInjectionExtensions
{
// 单独注入SignalR配置
public static ISignalRServerBuilder AddHubOptions<THub>(this ISignalRServerBuilder signalrBuilder, Action<HubOptions<THub>> configure) where THub : Hub
{
if (signalrBuilder == null)
{
throw new ArgumentNullException(nameof(signalrBuilder));
} signalrBuilder.Services.AddSingleton<IConfigureOptions<HubOptions<THub>>, HubOptionsSetup<THub>>();
signalrBuilder.Services.Configure(configure);
return signalrBuilder;
} // 添加SignalR服务
public static ISignalRServerBuilder AddSignalR(this IServiceCollection services)
{
if (services == null)
{
throw new ArgumentNullException(nameof(services));
}
// ConnectionsDependencyInjectionExtensions拓展类 添加请求路由、添加身份验证、添加Http连接调度程序、添加Http连接管理器
services.AddConnections();
// 禁用WebSocket保持活动,因为SignalR有它自己的
services.Configure<WebSocketOptions>(o => o.KeepAliveInterval = TimeSpan.Zero);
services.TryAddSingleton<SignalRMarkerService>();
services.TryAddEnumerable(ServiceDescriptor.Singleton<IConfigureOptions<HubOptions>, HubOptionsSetup>());
//调用 Microsoft.AspNetCore.SignalR.Core 类库中的 SignalRDependencyInjectionExtensions
return services.AddSignalRCore();
} // 添加SignalR服务。注入SignalR配置信息
public static ISignalRServerBuilder AddSignalR(this IServiceCollection services, Action<HubOptions> configure)
{
if (services == null)
{
throw new ArgumentNullException(nameof(services));
} var signalrBuilder = services.AddSignalR();
services.Configure(configure);
return signalrBuilder;
}
}

Microsoft.AspNetCore.SignalR.Core类库中的SignalRDependencyInjectionExtensions解读
这里面注入了SignalR中核心类,所以下面的代码我们一定要仔细研读了。

public static class SignalRDependencyInjectionExtensions
{
// 将最小的基本SignalR服务添加IServiceCollection 中
public static ISignalRServerBuilder AddSignalRCore(this IServiceCollection services)
{
// 用于标记SignalR是否注入
services.TryAddSingleton<SignalRCoreMarkerService>();
// 注入默认集线器生命周期管理器
services.TryAddSingleton(typeof(HubLifetimeManager<>), typeof(DefaultHubLifetimeManager<>));
// 注入默认集线器协议解析器
services.TryAddSingleton(typeof(IHubProtocolResolver), typeof(DefaultHubProtocolResolver));
// 注入集线器上下文
services.TryAddSingleton(typeof(IHubContext<>), typeof(HubContext<>));
services.TryAddSingleton(typeof(IHubContext<,>), typeof(HubContext<,>));
// 注入集线器中心连接处理程序
services.TryAddSingleton(typeof(HubConnectionHandler<>), typeof(HubConnectionHandler<>));
// 注入获取用户唯一标识方法
services.TryAddSingleton(typeof(IUserIdProvider), typeof(DefaultUserIdProvider));
// 注入默认中心调度员
services.TryAddSingleton(typeof(HubDispatcher<>), typeof(DefaultHubDispatcher<>));
// 注入默认激活中心
services.TryAddScoped(typeof(IHubActivator<>), typeof(DefaultHubActivator<>));
// 添加授权
services.AddAuthorization(); var builder = new SignalRServerBuilder(services);
// 添加Protocol转json
builder.AddJsonProtocol();
return builder;
}
}

SignalR集线器设计

通过Hub类可以看到程序集是Microsoft.AspNetCore.SignalR.Core

// Hub 是一个抽象类
public abstract class Hub : IDisposable
{
private bool _disposed;
// 客户端链接
private IHubCallerClients _clients = default!;
// 集线器呼叫中心上下文
private HubCallerContext _context = default!;
// 集线器组管理
private IGroupManager _groups = default!;
// 客户端链接(管理所有用户链接)
public IHubCallerClients Clients
{
get
{
CheckDisposed();
return _clients;
}
set
{
CheckDisposed();
_clients = value;
}
}
// 集线器上下文(保存当前用户链接信息)
public HubCallerContext Context
{
get
{
CheckDisposed();
return _context;
}
set
{
CheckDisposed();
_context = value;
}
}
// 组管理(对于组进行添加或者删除)
public IGroupManager Groups
{
get
{
CheckDisposed();
return _groups;
}
set
{
CheckDisposed();
_groups = value;
}
} // 连接方法(用于兼容用户连接操作)
public virtual Task OnConnectedAsync()
{
return Task.CompletedTask;
} // 链接释放方法(用于监控用户下线操作)
public virtual Task OnDisconnectedAsync(Exception? exception)
{
return Task.CompletedTask;
} protected virtual void Dispose(bool disposing)
{
} public void Dispose()
{
if (_disposed)
{
return;
} Dispose(true); _disposed = true;
} private void CheckDisposed()
{
if (_disposed)
{
throw new ObjectDisposedException(GetType().Name);
}
}
}

SignalR中间件

通过MapHub可以看到使用的类是HubEndpointRouteBuilderExtensions

app.UseEndpoints(endpoints =>
{
endpoints.MapHub<ChatHub>("/ChatHub");
});

HubEndpointRouteBuilderExtensions源代码

public static class HubEndpointRouteBuilderExtensions
{
................................ // 注册集线器
public static HubEndpointConventionBuilder MapHub<[DynamicallyAccessedMembers(HubAccessibility)] THub>(this IEndpointRouteBuilder endpoints, string pattern, Action<HttpConnectionDispatcherOptions>? configureOptions) where THub : Hub
{
// 这个就是我们上面注册SignalR保留来判断是否注入
var marker = endpoints.ServiceProvider.GetService<SignalRMarkerService>(); if (marker == null)
{
throw new InvalidOperationException("Unable to find the required services. Please add all the required services by calling " +
"'IServiceCollection.AddSignalR' inside the call to 'ConfigureServices(...)' in the application startup code.");
}
// SignalR配置信息
var options = new HttpConnectionDispatcherOptions();
configureOptions?.Invoke(options); // endpoints.MapConnections用来接收第一次连接请求,然后开启对于协议连接
var conventionBuilder = endpoints.MapConnections(pattern, options, b =>
{
// SignalRConnectionBuilderExtensions拓展类(这里是一个重点,将我们的泛型集线器连接进行注入,就可以开始它的工作了)
b.UseHub<THub>();
}); ....................................
return new HubEndpointConventionBuilder(conventionBuilder);
}
}

SignalRConnectionBuilderExtensions源代码

public static class SignalRConnectionBuilderExtensions
{
public static IConnectionBuilder UseHub<[DynamicallyAccessedMembers(HubAccessibility)] THub>(this IConnectionBuilder connectionBuilder) where THub : Hub
{
var marker = connectionBuilder.ApplicationServices.GetService(typeof(SignalRCoreMarkerService));
if (marker == null)
{
throw new InvalidOperationException("Unable to find the required services. Please add all the required services by calling " +
"'IServiceCollection.AddSignalR' inside the call to 'ConfigureServices(...)' in the application startup code.");
}
// 1.connectionBuilder.UseConnectionHandler拓展方法在 ConnectionBuilderExtensions中
// 2.HubConnectionHandler这个不就是我们注入服务的集线器中心连接处理程序吗?
return connectionBuilder.UseConnectionHandler<HubConnectionHandler<THub>>();
}
}

ConnectionBuilderExtensions源代码

public static class ConnectionBuilderExtensions
{
// 执行集线器的连接方法,到了这里就代表本次连接成功了
public static IConnectionBuilder UseConnectionHandler<[DynamicallyAccessedMembers(DynamicallyAccessedMemberTypes.PublicConstructors)] TConnectionHandler>(this IConnectionBuilder connectionBuilder) where TConnectionHandler : ConnectionHandler
{
var handler = ActivatorUtilities.GetServiceOrCreateInstance<TConnectionHandler>(connectionBuilder.ApplicationServices); // 这是一个终端中间件,所以没有必要使用'next'参数
return connectionBuilder.Run(connection => handler.OnConnectedAsync(connection));
}
}

小结

通过services.AddSignalR()进行SignalR基础服务进行注册。
通过Hub抽象工程,由不同的集线器继承,定义同一的连接、断开方法、客户端连接管理、群组管理、当前上下文信息。
通过MapHub<ChatHub>通过中间件路由规则进行流量划分。
当我们看完上面调用链路,脑中是不是已经有了一个清晰的方向了,它是怎么与前端进行连接的,并且对于注入的服务有一定的了解。

HubConnectionHandler连接处理

我们已经知道进入中间件之后就会进入HubConnectionHandler.OnConnectedAsync()方法

    public override async Task OnConnectedAsync(ConnectionContext connection)
{
// 我们检查是否设置了HubOptions<THub>,因为它们优先于全局hub选项。
// 然后将keepAlive和handshakeTimeout值设置为HubOptionsSetup中的默认值,当它们显式地设置为null时。 var supportedProtocols = _hubOptions.SupportedProtocols ?? _globalHubOptions.SupportedProtocols;
if (supportedProtocols == null || supportedProtocols.Count == 0)
{
throw new InvalidOperationException("There are no supported protocols");
}
// 默认握手超时15分钟
var handshakeTimeout = _hubOptions.HandshakeTimeout ?? _globalHubOptions.HandshakeTimeout ?? HubOptionsSetup.DefaultHandshakeTimeout;
// 集线器连接配置
var contextOptions = new HubConnectionContextOptions()
{
KeepAliveInterval = _hubOptions.KeepAliveInterval ?? _globalHubOptions.KeepAliveInterval ?? HubOptionsSetup.DefaultKeepAliveInterval,
ClientTimeoutInterval = _hubOptions.ClientTimeoutInterval ?? _globalHubOptions.ClientTimeoutInterval ?? HubOptionsSetup.DefaultClientTimeoutInterval,
StreamBufferCapacity = _hubOptions.StreamBufferCapacity ?? _globalHubOptions.StreamBufferCapacity ?? HubOptionsSetup.DefaultStreamBufferCapacity,
MaximumReceiveMessageSize = _maximumMessageSize,
SystemClock = SystemClock,
MaximumParallelInvocations = _maxParallelInvokes,
}; Log.ConnectedStarting(_logger);
// 创建连接上下文,将用户信息添加到上下文中
var connectionContext = new HubConnectionContext(connection, contextOptions, _loggerFactory); var resolvedSupportedProtocols = (supportedProtocols as IReadOnlyList<string>) ?? supportedProtocols.ToList();
if (!await connectionContext.HandshakeAsync(handshakeTimeout, resolvedSupportedProtocols, _protocolResolver, _userIdProvider, _enableDetailedErrors))
{
return;
} // 已建立connectionContext try
{
// 默认集线器生命周期管理器(DefaultHubLifetimeManager)将当前用户添加到连接池中
await _lifetimeManager.OnConnectedAsync(connectionContext);
// 获取我们对应的集线器,执行OnConnectedAsync()方法,这个时候就真正的开始执行我们写的代码了。
// 里面有一个消息分配方法DispatchMessagesAsync(),获取我们交互的信息进行处理
await RunHubAsync(connectionContext);
}
finally
{
connectionContext.Cleanup(); Log.ConnectedEnding(_logger);
// 当处理消息方法跳出,之后代表当前用户已经断开连接了,所以我们需要触发断线方法
await _lifetimeManager.OnDisconnectedAsync(connectionContext);
}
}

SignalR异步分派消息

//  异步分派消息
private async Task DispatchMessagesAsync(HubConnectionContext connection)
{
var input = connection.Input;
var protocol = connection.Protocol;
connection.BeginClientTimeout(); var binder = new HubConnectionBinder<THub>(_dispatcher, connection); while (true)
{
var result = await input.ReadAsync();
var buffer = result.Buffer; try
{
if (result.IsCanceled)
{
break;
}
// 存在消息
if (!buffer.IsEmpty)
{
bool messageReceived = false;
// 没有消息限制,只是解析和分派
if (_maximumMessageSize == null)
{
while (protocol.TryParseMessage(ref buffer, binder, out var message))
{
connection.StopClientTimeout();
// 我们接收到了消息,停止超时检查
messageReceived = true;
// 将接收的消息,根据不同的类型进行分发处理
await _dispatcher.DispatchMessageAsync(connection, message);
} if (messageReceived)
{
// 处理完接收消息之后,开启超时检查
connection.BeginClientTimeout();
}
}
else
{
// 我们给解析器一个默认消息大小的滑动窗口
var maxMessageSize = _maximumMessageSize.Value; while (!buffer.IsEmpty)
{
var segment = buffer;
var overLength = false;
// 切分消息,慢慢进行处理
if (segment.Length > maxMessageSize)
{
segment = segment.Slice(segment.Start, maxMessageSize);
overLength = true;
} if (protocol.TryParseMessage(ref segment, binder, out var message))
{
connection.StopClientTimeout();
// 我们接收到了消息,停止超时检查
messageReceived = true;
// 将接收的消息,根据不同的类型进行分发处理
await _dispatcher.DispatchMessageAsync(connection, message);
}
else if (overLength)
{
throw new InvalidDataException($"The maximum message size of {maxMessageSize}B was exceeded. The message size can be configured in AddHubOptions.");
}
else
{
// No need to update the buffer since we didn't parse anything
break;
} // Update the buffer to the remaining segment
buffer = buffer.Slice(segment.Start);
} if (messageReceived)
{
connection.BeginClientTimeout();
}
}
} if (result.IsCompleted)
{
if (!buffer.IsEmpty)
{
throw new InvalidDataException("Connection terminated while reading a message.");
}
break;
}
}
finally
{
// 缓冲区被分割到它被消耗的地方,所以我们可以直接开始。 我们把检查标记为缓冲。 结束,如果我们没有收到完整的帧,我们将等待更多的数据 再读一遍之前。
input.AdvanceTo(buffer.Start, buffer.End);
}
}

SignalR针对用户发送消息

针对于群发消息,我们知道有一个组的容器,我们只要将大家添加到一个组中就可以了,那么我们想根据用户发送消息1:1的模式,SignalR源码中是怎么处理的呢?

在注册SignalR服务中我们可以看到这个services.TryAddSingleton(typeof(IUserIdProvider), typeof(DefaultUserIdProvider));

public class DefaultUserIdProvider : IUserIdProvider
{
// 获取当前用户标识
public virtual string? GetUserId(HubConnectionContext connection)
{
// 这个也就是为什么我们在不做任何处理之下想使用SignalR用户模式,需要在Jwt中添加一个ClaimTypes.NameIdentifier了
return connection.User.FindFirst(ClaimTypes.NameIdentifier)?.Value;
}
}

我们只需要自己定义一个实现类,将默认实现替换掉就可以了。

    // 用户模式发送源码
public override Task SendUserAsync(string userId, string methodName, object?[] args, CancellationToken cancellationToken = default)
{
// connection.UserIdentifier就是执行了GetUserId()方法获取的用户标识
return SendToAllConnections(methodName, args, (connection, state) => string.Equals(connection.UserIdentifier, (string)state!, StringComparison.Ordinal), userId, cancellationToken);
}

SignalR项目使用设计

上面我们已经讲完,SignalR从连接==>处理消息以及用户模式的源码设计,相信小伙伴已经脑海中已经有点东西了,那么就开始项目中实践方式

我主要负责提供基础SignalR库,给到不同的部门进行使用,所以我首先需要考虑到一个高内聚,低耦合的设计,这里我首先不能掺杂业务逻辑,但是又需要所有业务聚合到我这边,然后通过不同的业务进行不同的处理。
设计思路:

  • 定义两个接口IReceiveMessageISendMessage,接口中分别有MessageType属性,HandlerAsync(input)方法
  • 定义一个公用的集线器注入IEnumerable<IReceiveMessage>IEnumerable<ISendMessage>添加Receive(input)Send(input)方法通过不同的入参中的MessageType属性,从注入集合中获取对应的消息实现进行处理

集线器伪代码

    public class SignalRHub : Hub
{
private readonly IEnumerable<IReceiveMessage> _receiveMessages;
private readonly IEnumerable<ISendMessage> _sendMessages; public SignalRHub(IEnumerable<IReceiveMessage> receiveMessages,
IEnumerable<ISendMessage> sendMessages)
{
_receiveMessages = receiveMessages;
_sendMessages = sendMessages;
} public async Task Receive(SignalRReceiveMessage input)
{
await _receiveMessages.FirstOrDefault(x => string.Compare(x.MessageType, input.MessageType, true) == 0).HandlerAsync(input);
} public async Task Send(SignalRSendMessage outInput)
{
await _sendMessages.FirstOrDefault(x => string.Compare(x.MessageType, outInput.MessageType, true) == 0).HandlerAsync(outInput);
}
}

业务实现示例

    public class NotificationSendMessage : ISendMessage, ISingletonDependency
{
public string MessageType
{
get => SignalRSendMessageEnum.Notification.ToString();
} public Task HandlerAsync(SignalRSendMessage message)
{
//.......业务逻辑......
}
}

这样我就只需要接收消息,进行转发给对应实现就可以了,我给同事提供了SignalR服务,又不干涉他们的业务。

使用ABP SignalR重构消息服务(二)的更多相关文章

  1. 使用ABP SignalR重构消息服务(一)

    使用ABP SignalR重构消息服务 最近协助蟹老板升级新框架,维护基础设施服务,目前已经稳了. 早上蟹老板看到我进入公司,马上就叫停我,说我为什么左脚先进公司,你这样会让我很难做耶,这样把我给你一 ...

  2. 三:JMS消息服务规范

    一:JMS是什么?--->JMS即Java消息服务(Java Message Service)应用程序接口,是一个Java平台中关于面向消息中间件(MOM)的API--->用于在两个应用程 ...

  3. 基于SignalR的消息推送与二维码描登录实现

    1 概要说明 使用微信扫描登录相信大家都不会陌生吧,二维码与手机结合产生了不同应用场景,基于二维码的应用更是比较广泛.为了满足ios.android客户端与web短信平台的结合,特开发了基于Singl ...

  4. X-Admin&ABP框架开发-消息通知

    业务型网站使用过程中,消息通知是一个不可或缺的功能,采用站内通知.短信通知.邮件通知.微信通知等等各种方式都有,ABP框架对这部分工作已经封装的很好了,站在巨人的肩膀上,一览全貌,带来的就是心情舒畅. ...

  5. Signalr实现消息推送

    一.前言 大多数系统里面好像都有获取消息的功能,但这些消息来源都不是实时的,比如你开两个浏览器,用两个不同的账号登录,用一个账号给另外一个账号发送消息,然而并不会实时收到消息,必须要自己手动F5刷新一 ...

  6. AngularJS+ASP.NET MVC+SignalR实现消息推送

    原文:AngularJS+ASP.NET MVC+SignalR实现消息推送 背景 OA管理系统中,员工提交申请单,消息实时通知到相关人员及时进行审批,审批之后将结果推送给用户. 技术选择 最开始发现 ...

  7. JMS(java消息服务)整合Spring项目案例

    转载自云栖社区 摘要: Sprng-jms消息服务小项目 所需的包: spring的基础包 spring-jms-xx包 spring-message–xx包 commons-collection-x ...

  8. “一切都是消息”--MSF(消息服务框架)之【请求-响应】模式

    在前一篇, “一切都是消息”--MSF(消息服务框架)入门简介, 我们介绍了MSF基于异步通信,支持请求-响应通信模式和发布-订阅通信模式,并且介绍了如何获取MSF.今天,我们来看看如何使用MSF来做 ...

  9. “一切都是消息”--MSF(消息服务框架)之【发布-订阅】模式

    在上一篇,“一切都是消息”--MSF(消息服务框架)之[请求-响应]模式 ,我们演示了MSF实现简单的请求-响应模式的示例,今天来看看如何实现[发布-订阅]模式.简单来说,该模式的工作过程是: 客户端 ...

随机推荐

  1. Source Code Reading for Vue 3: How does `hasChanged` work?

    Hey, guys! The next generation of Vue has released already. There are not only the brand new composi ...

  2. 报错————Type interface com.ssm.mapper.NewProductMapper is not known to the MapperRegistry.

    报错: Exception in thread "main" org.apache.ibatis.binding.BindingException: Type interface ...

  3. 移动IP通信过程

    看了点资料,沿着自己的思路来整理一下计算机网络部分移动IP通信遇到的问题以及是怎样解决的.如有错误,欢迎纠正! 遇到问题,然后解决问题. 沿着这样一个思路我们可以看看移动IP通信和传统的网络通信有什么 ...

  4. 如何构建Docker镜像

    构建Docker 镜像有如下两种方法: (一)使用docker commit命令.(二)使用docker build命令和 Dockerfile 文件.在这里并不推荐使用docker commit来构 ...

  5. ZYNQ使用88E1510 PHY芯片的驱动程序

    SDK V2014.4 PHY 88E1510 PL端以太网,自协商 standalone应用程序 PL端设计,略. 根据PL端生成的hdf,新建项目,采用官方lwip echo server例程.发 ...

  6. ansible 三配置和命令集

    一.Ansible配置 Ansible安装好之后的配置文件有如下两种: 1.yum安装,配置文件默认路径为: /etc/ansible/ansible.cfg 2.源码包安装,配置文件路径需要从软件包 ...

  7. 通过DP总线实现S7-300/400与SINAMICS S120 通讯

    一.DP总线通讯功能概述 S7-300/400与SINAMICS S120 之间通过DP总线可进行周期性及非周期性数据通讯. 使用标准S7功能块SFC14/SFC15,S7-300/400PLC通过P ...

  8. 为什么我们调用 start()方法时会执行 run()方法,为什么 我们不能直接调用 run()方法?

    当你调用 start()方法时你将创建新的线程,并且执行在 run()方法里的代码. 但是如果你直接调用 run()方法,它不会创建新的线程也不会执行调用线程的代码, 只会把 run 方法当作普通方法 ...

  9. spring 支持哪些 ORM 框架 ?

    Hibernate iBatis JPA JDO OJB

  10. Java 死锁以及如何避免?

    Java 中的死锁是一种编程情况,其中两个或多个线程被永久阻塞,Java 死锁情况 出现至少两个线程和两个或更多资源. Java 发生死锁的根本原因是:在申请锁时发生了交叉闭环申请.