EventHubs MultipleConnectAsync Fail

栋 郭 1 Reputation point
2021-01-25T01:17:37.283+00:00

2021-01-24 02:24 - 2021-01-24 03:16 Connect EventHubs Fail With Message

{"ClassName":"System.Net.Sockets.SocketException","Message":"Name or service not known","Data":null,"InnerException":null,"HelpURL":null,"StackTraceString":" at Azure.Messaging.EventHubs.Amqp.AmqpConnectionScope.CreateAndOpenConnectionAsync(Version amqpVersion, Uri serviceEndpoint, EventHubsTransportType transportType, IWebProxy proxy, String scopeIdentifier, TimeSpan timeout)\n at Microsoft.Azure.Amqp.FaultTolerantAmqpObject1.OnCreateAsync(TimeSpan timeout)\n at Microsoft.Azure.Amqp.Singleton1.GetOrCreateAsync(TimeSpan timeout)\n at Microsoft.Azure.Amqp.Singleton1.GetOrCreateAsync(TimeSpan timeout)\n at Azure.Messaging.EventHubs.Amqp.AmqpConnectionScope.OpenProducerLinkAsync(String partitionId, TimeSpan timeout, CancellationToken cancellationToken)\n at Azure.Messaging.EventHubs.Amqp.AmqpProducer.CreateLinkAndEnsureProducerStateAsync(String partitionId, TimeSpan timeout, CancellationToken cancellationToken)\n at Microsoft.Azure.Amqp.FaultTolerantAmqpObject1.OnCreateAsync(TimeSpan timeout)\n at Microsoft.Azure.Amqp.Singleton1.GetOrCreateAsync(TimeSpan timeout)\n at Microsoft.Azure.Amqp.Singleton1.GetOrCreateAsync(TimeSpan timeout)\n at Azure.Messaging.EventHubs.Amqp.AmqpProducer.CreateBatchAsync(CreateBatchOptions options, CancellationToken cancellationToken)\n at Azure.Messaging.EventHubs.Amqp.AmqpProducer.CreateBatchAsync(CreateBatchOptions options, CancellationToken cancellationToken)\n at Azure.Messaging.EventHubs.Producer.EventHubProducerClient.CreateBatchAsync(CreateBatchOptions options, CancellationToken cancellationToken)\n at Azure.Messaging.EventHubs.Producer.EventHubProducerClient.CreateBatchAsync(CancellationToken cancellationToken)\n at IValon.Common.AzureEventHubs.EventHubsMessage.RunAsync(String eventHubName, String message)\n at IValon.Common.AzureEventHubs.EventHubsMessage.RunAsync(String eventHubName, String message)","RemoteStackTraceString":null,"RemoteStackIndex":0,"ExceptionMethod":null,"HResult":-2147467259,"Source":"System.Private.CoreLib","WatsonBuckets":null,"NativeErrorCode":-131073} MultipleConnectAsync.DnsCallback => MultipleConnectAsync.DoDnsCallback => MultipleConnectAsync.Fail

Azure Event Hubs
Azure Event Hubs
An Azure real-time data ingestion service.
591 questions
{count} votes

1 answer

Sort by: Most helpful
  1. Serkant Karaca 21 Reputation points Microsoft Employee
    2021-01-25T23:08:02.027+00:00

    Failure sounds like DNS resolution issue. Can you check couple things?

    • Check the connection string used by the client.
    • Check hostname DNS resolution failures on the VM where client failed.
    • Check DNS settings for network.