Rabbitmq 启用联合插件的请求-响应场景

Rabbitmq 启用联合插件的请求-响应场景,rabbitmq,masstransit,Rabbitmq,Masstransit,我有一个关于RabbitMQ联盟插件的一般性问题。这个插件能处理请求/响应场景吗?我的意思是向上游服务器发出请求并在下游服务器上做出响应。这可能吗 我测试了这个: 配置插件后,我向上游发送一个请求 服务器 消息到达下游服务器并正在发送 在那里消费 但当我在那里回应时,我得到了一个 EndpointNotFoundException(masstransit异常) 更多信息 我只在一个方向上配置了联邦(从上游到下游) respondsync在下游服务器上抛出的确切错误消息如下: MassTransi

我有一个关于RabbitMQ联盟插件的一般性问题。这个插件能处理请求/响应场景吗?我的意思是向上游服务器发出请求并在下游服务器上做出响应。这可能吗

我测试了这个:

  • 配置插件后,我向上游发送一个请求 服务器
  • 消息到达下游服务器并正在发送 在那里消费
  • 但当我在那里回应时,我得到了一个
    EndpointNotFoundException
    (masstransit异常)
  • 更多信息

    我只在一个方向上配置了联邦(从上游到下游)

    respondsync
    在下游服务器上抛出的确切错误消息如下:

    MassTransit.Messages Error: 0 : R-FAULT rabbitmq://DOWNSTREAMSERVER:5671/ClusteredRmqQueue N/A ClusteredRmqMessage RabbitMQConsumer.ClusteredRmqConsumer(00:00:42.0309281) The host was not found for the specified address: rabbitmq://UPSTREAMSERVER/bus-RabbitMQPublisher-rnuoyyrtr44jpo8wbdmo78a3y6?durable=false&autodelete=true, MassTransit.EndpointNotFoundException: The host was not found for the specified address: rabbitmq://UPSTREAMSERVER/bus-RabbitMQPublisher-rnuoyyrtr44jpo8wbdmo78a3y6?durable=false&autodelete=true
       at MassTransit.Transports.BusHostCollection`1.GetHost(Uri address)
       at MassTransit.RabbitMqTransport.Transport.RabbitMqSendTransportProvider.GetSendTransport(Uri address)
       at MassTransit.RabbitMqTransport.Transport.RabbitMqSendEndpointProvider.<GetSendEndpoint>d__6.MoveNext()
    --- End of stack trace from previous location where exception was thrown ---
       at System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()
       at System.Runtime.CompilerServices.TaskAwaiter.HandleNonSuccessAndDebuggerNotification(Task task)
       at MassTransit.Transports.SendEndpointCache.<GetSendEndpointFromProvider>d__7.MoveNext()
    --- End of stack trace from previous location where exception was thrown ---
       at System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()
       at System.Runtime.CompilerServices.TaskAwaiter.HandleNonSuccessAndDebuggerNotification(Task task)
       at MassTransit.Util.Caching.PendingValue`2.<CreateValue>d__6.MoveNext()
    --- End of stack trace from previous location where exception was thrown ---
       at System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()
       at System.Runtime.CompilerServices.TaskAwaiter.HandleNonSuccessAndDebuggerNotification(Task task)
       at MassTransit.Transports.SendEndpointCache.<GetSendEndpoint>d__5.MoveNext()
    --- End of stack trace from previous location where exception was thrown ---
       at System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()
       at System.Runtime.CompilerServices.TaskAwaiter.HandleNonSuccessAndDebuggerNotification(Task task)
       at MassTransit.Serialization.BaseConsumeContext.<GetSendEndpoint>d__46.MoveNext()
    --- End of stack trace from previous location where exception was thrown ---
       at System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()
       at System.Runtime.CompilerServices.TaskAwaiter.HandleNonSuccessAndDebuggerNotification(Task task)
       at MassTransit.Serialization.BaseConsumeContext.<RespondAsync>d__35`1.MoveNext()
    --- End of stack trace from previous location where exception was thrown ---
       at System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()
       at System.Runtime.CompilerServices.TaskAwaiter.HandleNonSuccessAndDebuggerNotification(Task task)
       at MassTransit.Pipeline.ConsumerFactories.DefaultConstructorConsumerFactory`1.<Send>d__0`1.MoveNext()
    --- End of stack trace from previous location where exception was thrown ---
       at System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()
       at System.Runtime.CompilerServices.TaskAwaiter.HandleNonSuccessAndDebuggerNotification(Task task)
       at MassTransit.Pipeline.Filters.ConsumerMessageFilter`2.<GreenPipes-IFilter<MassTransit-ConsumeContext<TMessage>>-Send>d__4.MoveNext()
    MOVE rabbitmq://DOWNSTREAMSERVER:5671/ClusteredRmqQueue N/A rabbitmq://DOWNSTREAMSERVER:5671/ClusteredRmqQueue_error?bind=true&queue=ClusteredRmqQueue_error Fault: The host was not found for the specified address: rabbitmq://UPSTREAMSERVER/bus-RabbitMQPublisher-rnuoyyrtr44jpo8wbdmo78a3y6?durable=false&autodelete=true
    Consumed: 0 - 0:14:21:22,0735704. THREAD: 3. Redelivered: True. IsDelivered: False. IsFaulted: False
    
    MassTransit.Messages错误:0:R故障rabbitmq://DOWNSTREAMSERVER:5671/ClusteredRmqQueue N/A ClusteredRmqMessage RabbitMQConsumer.ClusteredRmqConsumer(00:00:42.0309281)未找到指定地址的主机:rabbitmq://UPSTREAMSERVER/bus-RabbitMQPublisher-rnuoyyrtr44jpo8wbdmo78a3y6?durable=false&autodelete=true,MassTransit.EndpointNotFoundException:找不到指定地址的主机:rabbitmq://UPSTREAMSERVER/bus-RabbitMQPublisher-rnuoyyrtr44jpo8wbdmo78a3y6?durable=false&autodelete=true
    在MassTransit.Transports.BusHostCollection`1.GetHost(Uri地址)
    位于MassTransit.RabbitMqTransport.Transport.RabbitMqSendTransportProvider.GetSendTransport(Uri地址)
    在MassTransit.RabbitMqTransport.Transport.RabbitMqSendEndpointProvider.d__6.MoveNext()中
    ---来自引发异常的上一个位置的堆栈结束跟踪---
    在System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()中
    在System.Runtime.CompilerServices.TaskWaiter.HandleNonSuccessAndDebuggerNotification(任务任务)中
    在MassTransit.Transports.SendEndpointCache.d_u7.MoveNext()中
    ---来自引发异常的上一个位置的堆栈结束跟踪---
    在System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()中
    在System.Runtime.CompilerServices.TaskWaiter.HandleNonSuccessAndDebuggerNotification(任务任务)中
    在MassTransit.Util.Caching.PendingValue`2.d_u6.MoveNext()中
    ---来自引发异常的上一个位置的堆栈结束跟踪---
    在System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()中
    在System.Runtime.CompilerServices.TaskWaiter.HandleNonSuccessAndDebuggerNotification(任务任务)中
    在MassTransit.Transports.SendEndpointCache.d_u5.MoveNext()中
    ---来自引发异常的上一个位置的堆栈结束跟踪---
    在System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()中
    在System.Runtime.CompilerServices.TaskWaiter.HandleNonSuccessAndDebuggerNotification(任务任务)中
    在masstTransit.Serialization.baseConsumerContext.d__46.MoveNext()中
    ---来自引发异常的上一个位置的堆栈结束跟踪---
    在System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()中
    在System.Runtime.CompilerServices.TaskWaiter.HandleNonSuccessAndDebuggerNotification(任务任务)中
    在masstTransit.Serialization.baseConsumerContext.d_u35`1.MoveNext()中
    ---来自引发异常的上一个位置的堆栈结束跟踪---
    在System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()中
    在System.Runtime.CompilerServices.TaskWaiter.HandleNonSuccessAndDebuggerNotification(任务任务)中
    在MassTransit.Pipeline.ConsumerFactorys.DefaultConstructorConsumerFactory`1.d_u0`1.MoveNext()中
    ---来自引发异常的上一个位置的堆栈结束跟踪---
    在System.Runtime.ExceptionServices.ExceptionDispatchInfo.Throw()中
    在System.Runtime.CompilerServices.TaskWaiter.HandleNonSuccessAndDebuggerNotification(任务任务)中
    在MassTransit.Pipeline.Filters.ConsumerMessageFilter`2.d_u4.MoveNext()中
    移动rabbitmq://DOWNSTREAMSERVER:5671/ClusteredRmqQueue 不适用rabbitmq://DOWNSTREAMSERVER:5671/ClusteredRmqQueue_error?bind=true&queue=ClusteredRmqQueue_error 故障:找不到指定地址的主机:rabbitmq://UPSTREAMSERVER/bus-RabbitMQPublisher-rnuoyyrtr44jpo8wbdmo78a3y6?durable=false&autodelete=true
    消耗:0-0:14:21:220735704。线程:3。归还:对。IsDeliver:错误。IsFalse:错误