|
@@ -13,454 +13,88 @@ using MQTTnet.Core.Internal; |
|
|
|
|
|
|
|
|
namespace MQTTnet.Core.Client |
|
|
namespace MQTTnet.Core.Client |
|
|
{ |
|
|
{ |
|
|
public class MqttClientQueued : IMqttClient |
|
|
|
|
|
|
|
|
public class MqttClientQueued : MqttClient, IMqttClientQueued |
|
|
{ |
|
|
{ |
|
|
#region Fields |
|
|
|
|
|
private readonly IMqttCommunicationAdapterFactory _communicationChannelFactory; |
|
|
|
|
|
private readonly MqttPacketDispatcher _packetDispatcher; |
|
|
|
|
|
private readonly HashSet<ushort> _unacknowledgedPublishPackets; |
|
|
|
|
|
|
|
|
|
|
|
private MqttClientOptions _options; |
|
|
|
|
|
private bool _isReceivingPackets; |
|
|
|
|
|
|
|
|
private MqttClientQueuedOptions _options; |
|
|
private int _latestPacketIdentifier; |
|
|
private int _latestPacketIdentifier; |
|
|
private CancellationTokenSource _cancellationTokenSource; |
|
|
|
|
|
private IMqttCommunicationAdapter _adapter; |
|
|
|
|
|
|
|
|
|
|
|
//added |
|
|
|
|
|
private readonly ConcurrentQueue<MqttApplicationMessage> _inflightQueue; |
|
|
private readonly ConcurrentQueue<MqttApplicationMessage> _inflightQueue; |
|
|
private bool _usePersistance = false; |
|
|
private bool _usePersistance = false; |
|
|
private ConcurrentQueue<MqttApplicationMessage> _persistentQueue; |
|
|
|
|
|
#endregion |
|
|
|
|
|
|
|
|
private MqttClientQueuedPersistentMessagesManager _persistentMessagesManager; |
|
|
|
|
|
|
|
|
#region Ctrs |
|
|
|
|
|
public MqttClientQueued(IMqttCommunicationAdapterFactory communicationChannelFactory) |
|
|
|
|
|
|
|
|
public MqttClientQueued(IMqttCommunicationAdapterFactory communicationChannelFactory) : base(communicationChannelFactory) |
|
|
{ |
|
|
{ |
|
|
_communicationChannelFactory = communicationChannelFactory ?? throw new ArgumentNullException(nameof(communicationChannelFactory)); |
|
|
|
|
|
_packetDispatcher = new MqttPacketDispatcher(); |
|
|
|
|
|
_unacknowledgedPublishPackets = new HashSet<ushort>(); |
|
|
|
|
|
_inflightQueue = new ConcurrentQueue<MqttApplicationMessage>(); |
|
|
_inflightQueue = new ConcurrentQueue<MqttApplicationMessage>(); |
|
|
_persistentQueue = new ConcurrentQueue<MqttApplicationMessage>(); |
|
|
|
|
|
} |
|
|
} |
|
|
#endregion |
|
|
|
|
|
|
|
|
|
|
|
#region Events |
|
|
|
|
|
public event EventHandler Connected; |
|
|
|
|
|
public event EventHandler Disconnected; |
|
|
|
|
|
public event EventHandler<MqttApplicationMessageReceivedEventArgs> ApplicationMessageReceived; |
|
|
|
|
|
#endregion |
|
|
|
|
|
|
|
|
|
|
|
#region Poperties |
|
|
|
|
|
public bool IsConnected => _cancellationTokenSource != null && !_cancellationTokenSource.IsCancellationRequested; |
|
|
|
|
|
#endregion |
|
|
|
|
|
|
|
|
|
|
|
#region MqttClient Methods |
|
|
|
|
|
|
|
|
|
|
|
public async Task ConnectAsync(MqttClientOptions options) |
|
|
|
|
|
|
|
|
public async Task ConnectAsync(MqttClientQueuedOptions options) |
|
|
{ |
|
|
{ |
|
|
if (options == null) throw new ArgumentNullException(nameof(options)); |
|
|
|
|
|
|
|
|
|
|
|
ThrowIfConnected("It is not allowed to connect with a server after the connection is established."); |
|
|
|
|
|
|
|
|
|
|
|
try |
|
|
try |
|
|
{ |
|
|
|
|
|
|
|
|
{ |
|
|
_options = options; |
|
|
_options = options; |
|
|
_cancellationTokenSource = new CancellationTokenSource(); |
|
|
|
|
|
_latestPacketIdentifier = 0; |
|
|
|
|
|
_packetDispatcher.Reset(); |
|
|
|
|
|
|
|
|
|
|
|
_adapter = _communicationChannelFactory.CreateMqttCommunicationAdapter(options); |
|
|
|
|
|
|
|
|
|
|
|
MqttNetTrace.Verbose(nameof(MqttClient), "Trying to connect with server."); |
|
|
|
|
|
await _adapter.ConnectAsync(_options.DefaultCommunicationTimeout).ConfigureAwait(false); |
|
|
|
|
|
MqttNetTrace.Verbose(nameof(MqttClient), "Connection with server established."); |
|
|
|
|
|
|
|
|
|
|
|
await SetupIncomingPacketProcessingAsync(); |
|
|
|
|
|
|
|
|
this._usePersistance = _options.UsePersistence; |
|
|
|
|
|
await base.ConnectAsync(options); |
|
|
SetupOutgoingPacketProcessingAsync(); |
|
|
SetupOutgoingPacketProcessingAsync(); |
|
|
await AuthenticateAsync(options.WillMessage); |
|
|
|
|
|
|
|
|
|
|
|
MqttNetTrace.Verbose(nameof(MqttClient), "MQTT connection with server established."); |
|
|
|
|
|
|
|
|
|
|
|
if (_options.KeepAlivePeriod != TimeSpan.Zero) |
|
|
|
|
|
|
|
|
//load persistentMessages |
|
|
|
|
|
if (_usePersistance) |
|
|
{ |
|
|
{ |
|
|
StartSendKeepAliveMessages(_cancellationTokenSource.Token); |
|
|
|
|
|
|
|
|
if (_persistentMessagesManager == null) |
|
|
|
|
|
_persistentMessagesManager = new MqttClientQueuedPersistentMessagesManager(_options); |
|
|
|
|
|
await _persistentMessagesManager.LoadMessagesAsync(); |
|
|
|
|
|
await InternalPublishAsync(_persistentMessagesManager.GetMessages(), false); |
|
|
} |
|
|
} |
|
|
|
|
|
|
|
|
Connected?.Invoke(this, EventArgs.Empty); |
|
|
|
|
|
} |
|
|
} |
|
|
catch (Exception) |
|
|
catch (Exception) |
|
|
{ |
|
|
{ |
|
|
await DisconnectInternalAsync().ConfigureAwait(false); |
|
|
|
|
|
|
|
|
await DisconnectAsync().ConfigureAwait(false); |
|
|
throw; |
|
|
throw; |
|
|
} |
|
|
} |
|
|
} |
|
|
} |
|
|
|
|
|
|
|
|
public async Task DisconnectAsync() |
|
|
|
|
|
|
|
|
public new async Task PublishAsync(IEnumerable<MqttApplicationMessage> applicationMessages) |
|
|
{ |
|
|
{ |
|
|
if (!IsConnected) |
|
|
|
|
|
{ |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
try |
|
|
|
|
|
{ |
|
|
|
|
|
await SendAsync(new MqttDisconnectPacket()).ConfigureAwait(false); |
|
|
|
|
|
} |
|
|
|
|
|
finally |
|
|
|
|
|
{ |
|
|
|
|
|
await DisconnectInternalAsync().ConfigureAwait(false); |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
await InternalPublishAsync(applicationMessages, true); |
|
|
} |
|
|
} |
|
|
|
|
|
|
|
|
public async Task PublishAsync(IEnumerable<MqttApplicationMessage> applicationMessages) |
|
|
|
|
|
|
|
|
private async Task InternalPublishAsync(IEnumerable<MqttApplicationMessage> applicationMessages, bool appendIfUsePersistance) |
|
|
{ |
|
|
{ |
|
|
#pragma warning disable CS4014 // Because this call is not awaited, execution of the current method continues before the call is completed |
|
|
|
|
|
ThrowIfNotConnected(); |
|
|
ThrowIfNotConnected(); |
|
|
|
|
|
|
|
|
foreach (var applicationMessage in applicationMessages) |
|
|
foreach (var applicationMessage in applicationMessages) |
|
|
{ |
|
|
{ |
|
|
if (_usePersistance) |
|
|
|
|
|
_persistentQueue.Enqueue(applicationMessage); |
|
|
|
|
|
_inflightQueue.Enqueue(applicationMessage); |
|
|
|
|
|
} |
|
|
|
|
|
#pragma warning restore CS4014 // Because this call is not awaited, execution of the current method continues before the call is completed |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
public async Task<IList<MqttSubscribeResult>> SubscribeAsync(IEnumerable<TopicFilter> topicFilters) |
|
|
|
|
|
{ |
|
|
|
|
|
if (topicFilters == null) throw new ArgumentNullException(nameof(topicFilters)); |
|
|
|
|
|
|
|
|
|
|
|
ThrowIfNotConnected(); |
|
|
|
|
|
|
|
|
|
|
|
var subscribePacket = new MqttSubscribePacket |
|
|
|
|
|
{ |
|
|
|
|
|
PacketIdentifier = GetNewPacketIdentifier(), |
|
|
|
|
|
TopicFilters = topicFilters.ToList() |
|
|
|
|
|
}; |
|
|
|
|
|
|
|
|
|
|
|
var response = await SendAndReceiveAsync<MqttSubAckPacket>(subscribePacket).ConfigureAwait(false); |
|
|
|
|
|
|
|
|
if (_usePersistance && appendIfUsePersistance) |
|
|
|
|
|
await _persistentMessagesManager.SaveMessageAsync(applicationMessage); |
|
|
|
|
|
|
|
|
if (response.SubscribeReturnCodes.Count != subscribePacket.TopicFilters.Count) |
|
|
|
|
|
{ |
|
|
|
|
|
throw new MqttProtocolViolationException("The return codes are not matching the topic filters [MQTT-3.9.3-1]."); |
|
|
|
|
|
|
|
|
_inflightQueue.Enqueue(applicationMessage); |
|
|
} |
|
|
} |
|
|
|
|
|
|
|
|
return subscribePacket.TopicFilters.Select((t, i) => new MqttSubscribeResult(t, response.SubscribeReturnCodes[i])).ToList(); |
|
|
|
|
|
} |
|
|
} |
|
|
|
|
|
|
|
|
public async Task UnsubscribeAsync(IEnumerable<string> topicFilters) |
|
|
|
|
|
|
|
|
public new async Task<IList<MqttSubscribeResult>> SubscribeAsync(IEnumerable<TopicFilter> topicFilters) |
|
|
{ |
|
|
{ |
|
|
if (topicFilters == null) throw new ArgumentNullException(nameof(topicFilters)); |
|
|
|
|
|
|
|
|
|
|
|
ThrowIfNotConnected(); |
|
|
|
|
|
|
|
|
|
|
|
var unsubscribePacket = new MqttUnsubscribePacket |
|
|
|
|
|
{ |
|
|
|
|
|
PacketIdentifier = GetNewPacketIdentifier(), |
|
|
|
|
|
TopicFilters = topicFilters.ToList() |
|
|
|
|
|
}; |
|
|
|
|
|
|
|
|
|
|
|
await SendAndReceiveAsync<MqttUnsubAckPacket>(unsubscribePacket); |
|
|
|
|
|
|
|
|
return await base.SubscribeAsync(topicFilters); |
|
|
} |
|
|
} |
|
|
|
|
|
|
|
|
#region private |
|
|
|
|
|
private void ThrowIfNotConnected() |
|
|
private void ThrowIfNotConnected() |
|
|
{ |
|
|
{ |
|
|
if (!IsConnected) throw new MqttCommunicationException("The client is not connected."); |
|
|
if (!IsConnected) throw new MqttCommunicationException("The client is not connected."); |
|
|
} |
|
|
} |
|
|
|
|
|
|
|
|
private void ThrowIfConnected(string message) |
|
|
|
|
|
{ |
|
|
|
|
|
if (IsConnected) throw new MqttProtocolViolationException(message); |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private async Task SetupIncomingPacketProcessingAsync() |
|
|
|
|
|
{ |
|
|
|
|
|
_isReceivingPackets = false; |
|
|
|
|
|
|
|
|
|
|
|
#pragma warning disable CS4014 // Because this call is not awaited, execution of the current method continues before the call is completed |
|
|
|
|
|
Task.Factory.StartNew( |
|
|
|
|
|
() => ReceivePackets(_cancellationTokenSource.Token), |
|
|
|
|
|
_cancellationTokenSource.Token, |
|
|
|
|
|
TaskCreationOptions.LongRunning, |
|
|
|
|
|
TaskScheduler.Default).ConfigureAwait(false); |
|
|
|
|
|
#pragma warning restore CS4014 // Because this call is not awaited, execution of the current method continues before the call is completed |
|
|
|
|
|
|
|
|
|
|
|
while (!_isReceivingPackets && _cancellationTokenSource != null && !_cancellationTokenSource.IsCancellationRequested) |
|
|
|
|
|
{ |
|
|
|
|
|
await Task.Delay(TimeSpan.FromMilliseconds(100)); |
|
|
|
|
|
} |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private async Task AuthenticateAsync(MqttApplicationMessage willApplicationMessage) |
|
|
|
|
|
{ |
|
|
|
|
|
var connectPacket = new MqttConnectPacket |
|
|
|
|
|
{ |
|
|
|
|
|
ClientId = _options.ClientId, |
|
|
|
|
|
Username = _options.UserName, |
|
|
|
|
|
Password = _options.Password, |
|
|
|
|
|
CleanSession = _options.CleanSession, |
|
|
|
|
|
KeepAlivePeriod = (ushort)_options.KeepAlivePeriod.TotalSeconds, |
|
|
|
|
|
WillMessage = willApplicationMessage |
|
|
|
|
|
}; |
|
|
|
|
|
|
|
|
|
|
|
var response = await SendAndReceiveAsync<MqttConnAckPacket>(connectPacket).ConfigureAwait(false); |
|
|
|
|
|
if (response.ConnectReturnCode != MqttConnectReturnCode.ConnectionAccepted) |
|
|
|
|
|
{ |
|
|
|
|
|
throw new MqttConnectingFailedException(response.ConnectReturnCode); |
|
|
|
|
|
} |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private async Task ReceivePackets(CancellationToken cancellationToken) |
|
|
|
|
|
{ |
|
|
|
|
|
MqttNetTrace.Information(nameof(MqttClient), "Start receiving packets."); |
|
|
|
|
|
|
|
|
|
|
|
try |
|
|
|
|
|
{ |
|
|
|
|
|
while (!cancellationToken.IsCancellationRequested) |
|
|
|
|
|
{ |
|
|
|
|
|
_isReceivingPackets = true; |
|
|
|
|
|
|
|
|
|
|
|
var packet = await _adapter.ReceivePacketAsync(TimeSpan.Zero, cancellationToken).ConfigureAwait(false); |
|
|
|
|
|
if (cancellationToken.IsCancellationRequested) |
|
|
|
|
|
{ |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
StartProcessReceivedPacket(packet, cancellationToken); |
|
|
|
|
|
} |
|
|
|
|
|
} |
|
|
|
|
|
catch (OperationCanceledException) |
|
|
|
|
|
{ |
|
|
|
|
|
} |
|
|
|
|
|
catch (MqttCommunicationException exception) |
|
|
|
|
|
{ |
|
|
|
|
|
if (cancellationToken.IsCancellationRequested) |
|
|
|
|
|
{ |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
MqttNetTrace.Warning(nameof(MqttClient), exception, "MQTT communication exception while receiving packets."); |
|
|
|
|
|
await DisconnectInternalAsync().ConfigureAwait(false); |
|
|
|
|
|
} |
|
|
|
|
|
catch (Exception exception) |
|
|
|
|
|
{ |
|
|
|
|
|
MqttNetTrace.Error(nameof(MqttClient), exception, "Unhandled exception while receiving packets."); |
|
|
|
|
|
await DisconnectInternalAsync().ConfigureAwait(false); |
|
|
|
|
|
} |
|
|
|
|
|
finally |
|
|
|
|
|
{ |
|
|
|
|
|
MqttNetTrace.Information(nameof(MqttClient), "Stopped receiving packets."); |
|
|
|
|
|
} |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private void StartProcessReceivedPacket(MqttBasePacket packet, CancellationToken cancellationToken) |
|
|
|
|
|
{ |
|
|
|
|
|
#pragma warning disable CS4014 // Because this call is not awaited, execution of the current method continues before the call is completed |
|
|
|
|
|
Task.Run(() => ProcessReceivedPacketAsync(packet), cancellationToken).ConfigureAwait(false); |
|
|
|
|
|
#pragma warning restore CS4014 // Because this call is not awaited, execution of the current method continues before the call is completed |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private async Task ProcessReceivedPacketAsync(MqttBasePacket packet) |
|
|
|
|
|
{ |
|
|
|
|
|
try |
|
|
|
|
|
{ |
|
|
|
|
|
MqttNetTrace.Information(nameof(MqttClient), "Received <<< {0}", packet); |
|
|
|
|
|
|
|
|
|
|
|
if (packet is MqttPingReqPacket) |
|
|
|
|
|
{ |
|
|
|
|
|
await SendAsync(new MqttPingRespPacket()); |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
if (packet is MqttDisconnectPacket) |
|
|
|
|
|
{ |
|
|
|
|
|
await DisconnectAsync(); |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
if (packet is MqttPublishPacket publishPacket) |
|
|
|
|
|
{ |
|
|
|
|
|
await ProcessReceivedPublishPacket(publishPacket); |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
if (packet is MqttPubRelPacket pubRelPacket) |
|
|
|
|
|
{ |
|
|
|
|
|
await ProcessReceivedPubRelPacket(pubRelPacket); |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
_packetDispatcher.Dispatch(packet); |
|
|
|
|
|
} |
|
|
|
|
|
catch (Exception exception) |
|
|
|
|
|
{ |
|
|
|
|
|
MqttNetTrace.Error(nameof(MqttClient), exception, "Unhandled exception while processing received packet."); |
|
|
|
|
|
} |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private async Task ProcessReceivedPublishPacket(MqttPublishPacket publishPacket) |
|
|
|
|
|
{ |
|
|
|
|
|
if (publishPacket.QualityOfServiceLevel == MqttQualityOfServiceLevel.AtMostOnce) |
|
|
|
|
|
{ |
|
|
|
|
|
FireApplicationMessageReceivedEvent(publishPacket); |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
if (publishPacket.QualityOfServiceLevel == MqttQualityOfServiceLevel.AtLeastOnce) |
|
|
|
|
|
{ |
|
|
|
|
|
FireApplicationMessageReceivedEvent(publishPacket); |
|
|
|
|
|
await SendAsync(new MqttPubAckPacket { PacketIdentifier = publishPacket.PacketIdentifier }); |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
if (publishPacket.QualityOfServiceLevel == MqttQualityOfServiceLevel.ExactlyOnce) |
|
|
|
|
|
{ |
|
|
|
|
|
// QoS 2 is implement as method "B" [4.3.3 QoS 2: Exactly once delivery] |
|
|
|
|
|
lock (_unacknowledgedPublishPackets) |
|
|
|
|
|
{ |
|
|
|
|
|
_unacknowledgedPublishPackets.Add(publishPacket.PacketIdentifier); |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
FireApplicationMessageReceivedEvent(publishPacket); |
|
|
|
|
|
await SendAsync(new MqttPubRecPacket { PacketIdentifier = publishPacket.PacketIdentifier }); |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
throw new MqttCommunicationException("Received a not supported QoS level."); |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private Task ProcessReceivedPubRelPacket(MqttPubRelPacket pubRelPacket) |
|
|
|
|
|
{ |
|
|
|
|
|
lock (_unacknowledgedPublishPackets) |
|
|
|
|
|
{ |
|
|
|
|
|
_unacknowledgedPublishPackets.Remove(pubRelPacket.PacketIdentifier); |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
return SendAsync(pubRelPacket.CreateResponse<MqttPubCompPacket>()); |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private async Task DisconnectInternalAsync() |
|
|
|
|
|
{ |
|
|
|
|
|
var cts = _cancellationTokenSource; |
|
|
|
|
|
if (cts == null || cts.IsCancellationRequested) |
|
|
|
|
|
{ |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
cts.Cancel(false); |
|
|
|
|
|
cts.Dispose(); |
|
|
|
|
|
_cancellationTokenSource = null; |
|
|
|
|
|
|
|
|
|
|
|
try |
|
|
|
|
|
{ |
|
|
|
|
|
await _adapter.DisconnectAsync(_options.DefaultCommunicationTimeout).ConfigureAwait(false); |
|
|
|
|
|
MqttNetTrace.Information(nameof(MqttClient), "Disconnected from adapter."); |
|
|
|
|
|
} |
|
|
|
|
|
catch (Exception exception) |
|
|
|
|
|
{ |
|
|
|
|
|
MqttNetTrace.Warning(nameof(MqttClient), exception, "Error while disconnecting from adapter."); |
|
|
|
|
|
} |
|
|
|
|
|
finally |
|
|
|
|
|
{ |
|
|
|
|
|
Disconnected?.Invoke(this, EventArgs.Empty); |
|
|
|
|
|
} |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private void StartSendKeepAliveMessages(CancellationToken cancellationToken) |
|
|
|
|
|
{ |
|
|
|
|
|
#pragma warning disable CS4014 // Because this call is not awaited, execution of the current method continues before the call is completed |
|
|
|
|
|
Task.Factory.StartNew(() => SendKeepAliveMessagesAsync(cancellationToken), cancellationToken, TaskCreationOptions.LongRunning, TaskScheduler.Default).ConfigureAwait(false); |
|
|
|
|
|
#pragma warning restore CS4014 // Because this call is not awaited, execution of the current method continues before the call is completed |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private async Task SendKeepAliveMessagesAsync(CancellationToken cancellationToken) |
|
|
|
|
|
{ |
|
|
|
|
|
MqttNetTrace.Information(nameof(MqttClient), "Start sending keep alive packets."); |
|
|
|
|
|
|
|
|
|
|
|
try |
|
|
|
|
|
{ |
|
|
|
|
|
while (!cancellationToken.IsCancellationRequested) |
|
|
|
|
|
{ |
|
|
|
|
|
await Task.Delay(_options.KeepAlivePeriod, cancellationToken).ConfigureAwait(false); |
|
|
|
|
|
if (cancellationToken.IsCancellationRequested) |
|
|
|
|
|
{ |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
await SendAndReceiveAsync<MqttPingRespPacket>(new MqttPingReqPacket()).ConfigureAwait(false); |
|
|
|
|
|
} |
|
|
|
|
|
} |
|
|
|
|
|
catch (OperationCanceledException) |
|
|
|
|
|
{ |
|
|
|
|
|
} |
|
|
|
|
|
catch (MqttCommunicationException exception) |
|
|
|
|
|
{ |
|
|
|
|
|
if (cancellationToken.IsCancellationRequested) |
|
|
|
|
|
{ |
|
|
|
|
|
return; |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
MqttNetTrace.Warning(nameof(MqttClient), exception, "MQTT communication exception while sending/receiving keep alive packets."); |
|
|
|
|
|
await DisconnectInternalAsync().ConfigureAwait(false); |
|
|
|
|
|
} |
|
|
|
|
|
catch (Exception exception) |
|
|
|
|
|
{ |
|
|
|
|
|
MqttNetTrace.Warning(nameof(MqttClient), exception, "Unhandled exception while sending/receiving keep alive packets."); |
|
|
|
|
|
await DisconnectInternalAsync().ConfigureAwait(false); |
|
|
|
|
|
} |
|
|
|
|
|
finally |
|
|
|
|
|
{ |
|
|
|
|
|
MqttNetTrace.Information(nameof(MqttClient), "Stopped sending keep alive packets."); |
|
|
|
|
|
} |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private async Task<TResponsePacket> SendAndReceiveAsync<TResponsePacket>(MqttBasePacket requestPacket) where TResponsePacket : MqttBasePacket |
|
|
|
|
|
{ |
|
|
|
|
|
var packetAwaiter = _packetDispatcher.WaitForPacketAsync(requestPacket, typeof(TResponsePacket), _options.DefaultCommunicationTimeout); |
|
|
|
|
|
await _adapter.SendPacketsAsync(_options.DefaultCommunicationTimeout, _cancellationTokenSource.Token, requestPacket).ConfigureAwait(false); |
|
|
|
|
|
return (TResponsePacket)await packetAwaiter.ConfigureAwait(false); |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private Task SendAsync(MqttBasePacket packet) |
|
|
|
|
|
{ |
|
|
|
|
|
return _adapter.SendPacketsAsync(_options.DefaultCommunicationTimeout, _cancellationTokenSource.Token, packet); |
|
|
|
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
private ushort GetNewPacketIdentifier() |
|
|
private ushort GetNewPacketIdentifier() |
|
|
{ |
|
|
{ |
|
|
return (ushort)Interlocked.Increment(ref _latestPacketIdentifier); |
|
|
return (ushort)Interlocked.Increment(ref _latestPacketIdentifier); |
|
|
} |
|
|
} |
|
|
|
|
|
|
|
|
|
|
|
|
|
|
private void FireApplicationMessageReceivedEvent(MqttPublishPacket publishPacket) |
|
|
|
|
|
{ |
|
|
|
|
|
try |
|
|
|
|
|
{ |
|
|
|
|
|
var applicationMessage = publishPacket.ToApplicationMessage(); |
|
|
|
|
|
ApplicationMessageReceived?.Invoke(this, new MqttApplicationMessageReceivedEventArgs(applicationMessage)); |
|
|
|
|
|
} |
|
|
|
|
|
catch (Exception exception) |
|
|
|
|
|
{ |
|
|
|
|
|
MqttNetTrace.Error(nameof(MqttClient), exception, "Unhandled exception while handling application message."); |
|
|
|
|
|
} |
|
|
|
|
|
} |
|
|
|
|
|
#endregion |
|
|
|
|
|
#endregion |
|
|
|
|
|
|
|
|
|
|
|
#region MqttClientQueued Methos |
|
|
|
|
|
private void SetupOutgoingPacketProcessingAsync() |
|
|
private void SetupOutgoingPacketProcessingAsync() |
|
|
{ |
|
|
{ |
|
|
#pragma warning disable CS4014 // Because this call is not awaited, execution of the current method continues before the call is completed |
|
|
#pragma warning disable CS4014 // Because this call is not awaited, execution of the current method continues before the call is completed |
|
|
Task.Factory.StartNew( |
|
|
Task.Factory.StartNew( |
|
|
() => SendPackets(_cancellationTokenSource.Token), |
|
|
|
|
|
_cancellationTokenSource.Token, |
|
|
|
|
|
|
|
|
() => SendPackets(base._cancellationTokenSource.Token), |
|
|
|
|
|
base._cancellationTokenSource.Token, |
|
|
TaskCreationOptions.LongRunning, |
|
|
TaskCreationOptions.LongRunning, |
|
|
TaskScheduler.Default).ConfigureAwait(false); |
|
|
TaskScheduler.Default).ConfigureAwait(false); |
|
|
#pragma warning restore CS4014 // Because this call is not awaited, execution of the current method continues before the call is completed |
|
|
#pragma warning restore CS4014 // Because this call is not awaited, execution of the current method continues before the call is completed |
|
|
|
|
|
|
|
|
//while (_cancellationTokenSource != null && !_cancellationTokenSource.IsCancellationRequested) |
|
|
|
|
|
//{ |
|
|
|
|
|
// await Task.Delay(TimeSpan.FromMilliseconds(100)); |
|
|
|
|
|
//} |
|
|
|
|
|
} |
|
|
} |
|
|
|
|
|
|
|
|
private async Task SendPackets(CancellationToken cancellationToken) |
|
|
private async Task SendPackets(CancellationToken cancellationToken) |
|
@@ -480,21 +114,21 @@ namespace MQTTnet.Core.Client |
|
|
case MqttQualityOfServiceLevel.AtMostOnce: |
|
|
case MqttQualityOfServiceLevel.AtMostOnce: |
|
|
{ |
|
|
{ |
|
|
// No packet identifier is used for QoS 0 [3.3.2.2 Packet Identifier] |
|
|
// No packet identifier is used for QoS 0 [3.3.2.2 Packet Identifier] |
|
|
await _adapter.SendPacketsAsync(_options.DefaultCommunicationTimeout, _cancellationTokenSource.Token, publishPacket); |
|
|
|
|
|
|
|
|
await base._adapter.SendPacketsAsync(_options.DefaultCommunicationTimeout, base._cancellationTokenSource.Token, publishPacket); |
|
|
break; |
|
|
break; |
|
|
} |
|
|
} |
|
|
|
|
|
|
|
|
case MqttQualityOfServiceLevel.AtLeastOnce: |
|
|
case MqttQualityOfServiceLevel.AtLeastOnce: |
|
|
{ |
|
|
{ |
|
|
publishPacket.PacketIdentifier = GetNewPacketIdentifier(); |
|
|
publishPacket.PacketIdentifier = GetNewPacketIdentifier(); |
|
|
await SendAndReceiveAsync<MqttPubAckPacket>(publishPacket); |
|
|
|
|
|
|
|
|
await base.SendAndReceiveAsync<MqttPubAckPacket>(publishPacket); |
|
|
break; |
|
|
break; |
|
|
} |
|
|
} |
|
|
case MqttQualityOfServiceLevel.ExactlyOnce: |
|
|
case MqttQualityOfServiceLevel.ExactlyOnce: |
|
|
{ |
|
|
{ |
|
|
publishPacket.PacketIdentifier = GetNewPacketIdentifier(); |
|
|
publishPacket.PacketIdentifier = GetNewPacketIdentifier(); |
|
|
var pubRecPacket = await SendAndReceiveAsync<MqttPubRecPacket>(publishPacket).ConfigureAwait(false); |
|
|
|
|
|
await SendAndReceiveAsync<MqttPubCompPacket>(pubRecPacket.CreateResponse<MqttPubRelPacket>()).ConfigureAwait(false); |
|
|
|
|
|
|
|
|
var pubRecPacket = await base.SendAndReceiveAsync<MqttPubRecPacket>(publishPacket).ConfigureAwait(false); |
|
|
|
|
|
await base.SendAndReceiveAsync<MqttPubCompPacket>(pubRecPacket.CreateResponse<MqttPubRelPacket>()).ConfigureAwait(false); |
|
|
break; |
|
|
break; |
|
|
} |
|
|
} |
|
|
default: |
|
|
default: |
|
@@ -502,6 +136,9 @@ namespace MQTTnet.Core.Client |
|
|
throw new InvalidOperationException(); |
|
|
throw new InvalidOperationException(); |
|
|
} |
|
|
} |
|
|
} |
|
|
} |
|
|
|
|
|
//delete from persistence |
|
|
|
|
|
if (_usePersistance) |
|
|
|
|
|
await _persistentMessagesManager.Remove(messageToSend); |
|
|
} |
|
|
} |
|
|
}; |
|
|
}; |
|
|
} |
|
|
} |
|
@@ -518,13 +155,12 @@ namespace MQTTnet.Core.Client |
|
|
catch (Exception exception) |
|
|
catch (Exception exception) |
|
|
{ |
|
|
{ |
|
|
MqttNetTrace.Error(nameof(MqttClient), exception, "Unhandled exception while sending packets."); |
|
|
MqttNetTrace.Error(nameof(MqttClient), exception, "Unhandled exception while sending packets."); |
|
|
await DisconnectInternalAsync().ConfigureAwait(false); |
|
|
|
|
|
|
|
|
await DisconnectAsync().ConfigureAwait(false); |
|
|
} |
|
|
} |
|
|
finally |
|
|
finally |
|
|
{ |
|
|
{ |
|
|
MqttNetTrace.Information(nameof(MqttClient), "Stopped sending packets."); |
|
|
MqttNetTrace.Information(nameof(MqttClient), "Stopped sending packets."); |
|
|
} |
|
|
} |
|
|
} |
|
|
} |
|
|
#endregion |
|
|
|
|
|
} |
|
|
} |
|
|
} |
|
|
} |