Restricting azure service bus access to certain IP range

I am using service bus from two cloud services WebRoleC1 and WorkerRoleC2.
on pushes some data and other received data by subscribing to topics.
Every application maintains the service bus connection details in its web/cloud config. Everything works fine. 
I have multiple instance running of the same application for different customers , people make confusion while deploying and Put wrong connection details in say WorkerRoleC2 so it connects to  Service bus of another customer. 
I want to put restriction on service bus SB1 that only   WebRoleC1  and WorkerRoleC2 can connect to it. If WorkerRoleC3 has the proper key then also connection should fail.
This also prevents people from attacking service bus if now public ip.
I don't want service bus to publicly exposed.
Thanks,
Subodh

Service Bus does allow you to restrict receive access to specific subscriptions. You can set credentials such that a client 1 can receive messages from a specific subscription whereas a client 2 cannot.

Similar Messages

  • BizTalk 2013 SB-Messaging Adapter: Unable to receive messages from a Azure service bus Subscription

    Hi,
    I am trying to receive messages from a Azure service bus subscription using SB-Messaging Adapter in BizTalk Server 2013 but getting the following error.
    "The token provider was unable to provide a security token while accessing 'https://overcasb-sb.accesscontrol.windows.net/WRAPv0.9/'.
    Error Code: 407 Proxy Authentication Required. The ISA Server requires authorization to fulfill the request. Access to the Web Proxy filter is denied. (12209)
    It seems the error is related with Service Bus Authentication and Authorization with the Access Control Service. Can anybody help me out if I am missing something here? 
    Also for consuming the AWSB (namespace, topic name, subscription name, Issuer name, Issuer Key) I have referred the following link
    http://soa-thoughts.blogspot.in/2013/02/biztalk-server-2013-new-adapters-series.html
    Thanks!
    Regards,
    Gautam
    gautam

    Hi,
    When I am trying to receive the same messages from a Azure service bus subscription using .net (C#) client,
    BusSubscriberbusSubscriber =
    newBusSubscriber("TestTopic2",
    "Endpoint=sb://overcasb.servicebus.windows.net/;SharedSecretIssuer=owner;SharedSecretValue=wqYlT4yHZimeUZacH+1V1hj/ZrKu7zK9ELaaLYDxqjc=",
    "AssetMovement",
    "AssetMovement");
    I am getting the same error here also.
    "The token provider was unable to provide a security token while accessing 'https://overcasb-sb.accesscontrol.windows.net/WRAPv0.9/'.
    Error Code: 407 Proxy Authentication Required. The ISA Server requires authorization to fulfill the request. Access to the Web Proxy filter is denied. (12209)
    By setting  <defaultProxy useDefaultCredentials="true" /> in appconfig, I got rid of the above error. And now its working fine with .net(C#) client.
    <configuration>
      <system.net>
        <defaultProxy useDefaultCredentials="true" />
      </system.net>
    </configuration>
    The same setting I tried in BTSNTSvc.exe config file and ofcourse restarted the host instance but still getting the same error. Any help?
    gautam

  • Which Nuget Package for Azure Service Bus can I use for Windows Store apps?

    Hi,
    I want to use the Azure Service Bus Topics. I have an app that needs to subscribe to the Service bus Topic. The Nuget-Package for Azure Service Bus is not applicable for Windows Store Apps (I get an error during install), thats why I used the Windows Azure
    Service Bus managed for Windows Store. Unfortunatelly this API throws a Serialization Exception when I create a subscription. What can I do to use the Service bus in Windows store apps?
    Thats how I try to create the subscription:
    await Microsoft.WindowsAzure.Messaging.Subscription.CreateAsync(TOPIC_NAME, SUBSCRIPTION_NAME, CONNECTION_STRING);

    Yes this is the one I used.
    But creating a subscription with the code above throws the SerializationException mentioned in this question:
    http://social.msdn.microsoft.com/Forums/de-DE/1acb887e-d5f1-4bfb-8eb9-f8ce7390ae7b/microsoftwindowsazuremessagingsubscriptioncreateasync-throws-an?forum=servbus&prof=required.
    Maybe I do something wrong? Do I Need to do something before creating the subscription?
    I haven't found any sample that shows how you can subscribe to a Topic and receive Messages using the restricted Api for winrt :(
    Any suggestions?

  • Azure Service Bus client: Best way to wait for server response?

    Hi,
    I have a web service that needs to send a request on Azure Service Bus and wait for the response. The web service must operate synchronous as seen from the web service client, that is:
    public Response WebServiceMethod(Request)
    senderQueueClient.Send(Request);
    // wait for response from receiverQueueClient
    // and return to web serviuce client
    return response;
    This can be solved using mutexes that are updated in "receiverClientQueue.OnMessage". But that is hard work and if I Google the matter, I find several options to deal with this - especially when using .NET 4.5.  And there are also some built-in
    stuff in the QueueClient.
    But how to do this best? Can someone point me in the right (easy) direction?
    Werner

    Hi,
    May I know what are you use queue to achieve? can you give us further information for a better help.
    Regards

  • Some concept confused for Azure Service Bus EventHub

    Currently, I’m trying to use the Azure Service Bus Event hub and I have some concepts a little bit confused:
    I have create an event hub (our requirement is send 10Kb data per seconds to the event hub), the hub include 10 partitions, then we receive the data using the
    EventHubReceiver, when I create the instance for the EventHubReceiver, it need the
    PartitionId, so I want to know which partitionId is needed?
     I guess all the Partitions have the same data which I sended, is it right?
    Is the PartitionId equals PartitionKey? My understanding is the PartitionId is the indicator for the Partitions in the Event Hub, the PartitionKey is the indicator for the device which send the data, so one Partition can contains many partitonIds,
    is it right?
    When we receive data from hub, we need set the Consumer Group, so what is the relationship between EventHub and Consumer group?
    When we use the EventProcessorHost to receive data, we do not to set the PartitionId, so the data we got is the all PartitionData?
    When we call the PartitionContext.CheckpointAsync(), the Event hub will do the things to release the Events(delete, clear or sth) by itself, we needn’t do it in our code,
    is it right?
    Is there a diagram to show the relationship for concepts of the EventHub?
    Thanks a lot!

    I'd ask them over here.
    Azure forums on MSDN
    Regards, Dave Patrick ....
    Microsoft Certified Professional
    Microsoft MVP [Windows]
    Disclaimer: This posting is provided "AS IS" with no warranties or guarantees , and confers no rights.

  • Azure Service Bus Relay & Impersonation

    Hi All,
    I am currently investigating the use of Azure Service Bus Relay for a project, testing has gone well so far and I have a service and client communicating via the service bus relay.
    Currently the client and server are able to take part in two way communication, whereby the client invokes a method and a response is sent back to the client, the problem I have is that I now
    want the service to impersonate the user calling the methods, but only for some of the methods available in the service.  Is this possible over a service bus relay connection? if so, how can this be achieved. 
    I have been able to get this working when calling the service over a non-service bus binding (using basic authentication over SSL), but this fails when binding to the service bus relay, I believe because the HTTP context is lost between the client and
    server when communicating via the intermediary (in this case the service bus)
    Thanks in advance for the advice.
    Chris

    Hi,
    I would suggest that you contact to Azure Support for respective subscription
    Please refer following to know how to submit support ticket
    http://blogs.msdn.com/b/mast/archive/2013/01/22/windows-azure-customer-support-offerings-live-how-to-contact-microsoft-windows-azure-technical-support.aspx
    hope this helps

  • Azure service bus queue: Why do I keep getting a MessageLockLostException?

    I read a post that dealt with the same problem I'm having. It is located at https://social.msdn.microsoft.com/Forums/en-US/069653b5-c233-4942-85b2-9eb50b3865c7/azure-service-bus-subscription-how-do-i-delete-the-message-when-i-receive-a?forum=servbus
    I'm calling message.Complete() and I'm getting the MessageLockLostException but the difference with my issue is that I used the code that someone posted to fix the issue and it isn't working for me. I have pasted my full code below to show you how my program
    is working. What am I doing wrong and/or how do I fix this issue?
    static void Main(string[] args)
    try
    string connectionString = CloudConfigurationManager.GetSetting("Microsoft.ServiceBus.ConnectionString");
    QueueClient client = QueueClient.CreateFromConnectionString(connectionString, "OoplesQueue");
    var actionBlock = new ActionBlock<BrokeredMessage>(async message =>
    await processCalculations(message),
    new ExecutionDataflowBlockOptions
    MaxDegreeOfParallelism = Environment.ProcessorCount
    var produceMessagesTask = Task.Run(async () => await
    ProduceBrokeredMessagesAsync(client,
    actionBlock));
    produceMessagesTask.Wait();
    catch (Exception ex)
    Console.WriteLine(ex.Message);
    Console.WriteLine(ex.StackTrace);
    private static async Task ProduceBrokeredMessagesAsync(QueueClient client,
    ActionBlock<BrokeredMessage> actionBlock)
    BrokeredMessage message;
    while ((message = await client.ReceiveAsync()) != null)
    await actionBlock.SendAsync(message);
    public static ConnectionMultiplexer connection;
    public static IDatabase cache;
    public static async Task processCalculations(BrokeredMessage message)
    var brokeredMessageRenewCancellationTokenSource = new CancellationTokenSource();
    try
    if (message != null)
    if (connection == null || !connection.IsConnected)
    connection = await ConnectionMultiplexer.ConnectAsync("connectionString");
    //connection = ConnectionMultiplexer.Connect("ConnectionString,SyncTimeout=10000,ConnectTimeout=10000");
    cache = connection.GetDatabase();
    var brokeredMessageRenew = Task.Run(async () =>
    while (!brokeredMessageRenewCancellationTokenSource.Token.IsCancellationRequested)
    //Based on LockedUntilUtc property to determine if the lock expires soon
    if (DateTime.UtcNow > message.LockedUntilUtc.AddSeconds(-10))
    // If so, we repeat the message
    await message.RenewLockAsync();
    }, brokeredMessageRenewCancellationTokenSource.Token);
    string sandpKey = message.Properties["sandp"].ToString();
    string dateKey = message.Properties["date"].ToString();
    string symbolclassKey = message.Properties["symbolclass"].ToString();
    string stockdataKey = message.Properties["stockdata"].ToString();
    string stockcomparedataKey = message.Properties["stockcomparedata"].ToString();
    var sandpTask = cache.GetAsync<List<StockData>>(sandpKey);
    var dateTask = cache.GetAsync<DateTime>(dateKey);
    var symbolinfoTask = cache.GetAsync<SymbolInfo>(symbolclassKey);
    var stockdataTask = cache.GetAsync<List<StockData>>(stockdataKey);
    var stockcomparedataTask = cache.GetAsync<List<StockMarketCompare>>(stockcomparedataKey);
    await Task.WhenAll(sandpTask, dateTask, symbolinfoTask,
    stockdataTask, stockcomparedataTask);
    List<StockData> sandp = sandpTask.Result;
    DateTime date = dateTask.Result;
    SymbolInfo symbolinfo = symbolinfoTask.Result;
    List<StockData> stockdata = stockdataTask.Result;
    List<StockMarketCompare> stockcomparedata = stockcomparedataTask.Result;
    StockRating rating = performCalculations(symbolinfo, date, sandp, stockdata, stockcomparedata);
    if (rating != null)
    saveToTable(rating);
    await message.CompleteAsync();
    else
    Console.WriteLine("Message " + message.MessageId + " Completed!");
    await message.CompleteAsync();
    catch (TimeoutException time)
    Console.WriteLine(time.Message);
    catch (MessageLockLostException locks)
    Console.WriteLine(locks.Message);
    catch (RedisConnectionException redis)
    Console.WriteLine("Start the redis server service!");
    catch (MessagingCommunicationException communication)
    Console.WriteLine(communication.Message);
    catch (Exception ex)
    Console.WriteLine(ex.Message);
    Console.WriteLine(ex.StackTrace);
    finally
    // Lock is stopped renewing task
    brokeredMessageRenewCancellationTokenSource.Cancel();

    Below check assumes there's no clock skew between you and the Service Bus server. If there's a time difference more than 10 seconds then you may end up with renew attempts after message expires.
    if (DateTime.UtcNow
    > message.LockedUntilUtc.AddSeconds(-10))
    And I suggest you to add a sleep in the renew loop. It's an overkill to make this check a million times every second. Doing this once a second should be fine.

  • Receive location using SBMessaging adapter disabled when Azure service bus is down

    Does anybody experience  SBMessaging receive locations are disabled when Azure service bus is unavailable with a MessagingCommunicationException?  Is this an expected behavior / 'by design'? We see this exception a few times a day.  I don't
    see any retry attempts based on the event log.  Our current solution is to have a powershell script that enables the receive location if it's disabled.  This script runs every 15 minutes.  Below is a sample of the error in the event log.
    The receive location "Warnings_SB_New" with URL "XXXXXX" is shutting down. Details:"System.ServiceModel.EndpointNotFoundException: Error during communication with Service Bus. Check the connection information, then retry. --->
    Microsoft.ServiceBus.Messaging.MessagingCommunicationException: Error during communication with Service Bus. Check the connection information, then retry. ---> System.ServiceModel.CommunicationObjectFaultedException: Internal Server Error: The server did
    not provide a meaningful reply; this might be caused by a premature session shutdown..TrackingId:bb29d71c-a4d5-430c-a2d9-8a2e3acfad1d, Timestamp:5/9/2014 2:38:19 AM

    Hi R. de Veen,
    Below as the script we used with BTS2013.  We created a command line and setup a scheduled task.  Again, we don't use this script with BTS2013R2 since we do not have this issue with BTS2013 R2.
    # Sample from https://github.com/tomasr/bts-ps-scripts/blob/master/bts-ports.ps
    # declare our parameters: the action to take
    param(
    [string] $action=$(throw 'need action'),
    [string] $name
    $ctpRLs = @(
    'Errors_SB_New'
    #,'Error_OldTopic_OldLoggingDB'
    ,'Information_SB_New'
    ,'Warnings_SB_New'
    #,'Information_NewTopic_OldLoggingDB'
    ,'Critical_SB_New'
    #'Critical_OldTopic_OldLoggingDB'
    # functions for pinging receive locations
    function uti-ping-recv-loc
    foreach ($rl in $ctpRLs)
    Write-Host "`n"
    if (( $rl -eq '') -or ($rl -eq $null))
    throw "Receive location cannot be blank."
    #Validate if this is a valid receive location
    $recvloc = get-wmiobject MSBTS_ReceiveLocation `
    -namespace 'root\MicrosoftBizTalkServer' `
    -filter "Name='$rl'"
    if ($recvloc -eq $null)
    Write-Host "'$rl' does not exist. Skipping..." -foregroundcolor red -backgroundcolor black
    else
    Write-Host "Ping '$rl'..."
    if ($recvloc.IsDisabled)
    Write-Host "Restarting '$rl'..."
    bts-set-recv-loc-status -name $rl -status 'enable'
    Start-Sleep -s 10
    if ($recvloc.IsDisabled)
    Write-Host "Failed to enable $rl. Check the event log for more information." -foregroundcolor red -backgroundcolor black
    else
    Write-Host "'$rl' is enabled."
    else
    Write-Host "'$rl' is enabled."
    $i++
    Write-Host "`nComplete!!!`n`n" -foregroundcolor green -backgroundcolor black
    # enable or disable the specified
    # receive location
    function bts-set-recv-loc-status($name, $status)
    $recvloc = get-wmiobject MSBTS_ReceiveLocation `
    -namespace 'root\MicrosoftBizTalkServer' `
    -filter "Name='$name'"
    switch ( $status )
    'disable' { [void]$recvloc.Disable() }
    'enable' { [void]$recvloc.Enable() }
    # controls a send port
    function bts-set-send-port-status($name, $status)
    $sendport = get-wmiobject MSBTS_sendPort `
    -namespace 'root\MicrosoftBizTalkServer' `
    -filter "Name='$name'"
    switch ( $status )
    'start' { [void]$sendport.Start() }
    'stop' { [void]$sendport.Stop() }
    'enlist' { [void]$sendport.Enlist() }
    'unenlist' { [void]$sendport.UnEnlist() }
    function is-valid-opt($check, $options)
    foreach ( $val in $options )
    if ( $check -eq $val ) {
    return $true
    # main script
    switch ( $action )
    'ping-recv-loc' {
    uti-ping-recv-loc
    Write-Host "`n"
    Write-Host "Syntax: .\RestartELCRLs.ps1 ping-recv-loc"
    Write-Host "`n"

  • Azure service bus problem : An error occurred while retrieving the Service Bus namespace configuration information

    Almost all of my service bus has the following issue. The error message I have from the Management Portal was "An error occurred while retrieving the Service Bus namespace configuration information. Please try again later." This happen for almost
    2 days.
    Anyone face the same issue? how to resolve this?

    Hi,
    If you create a new one, did you receive the same issue? If that, I suggest you submit a ticket at:
    http://www.windowsazure.com/en-us/support/contact/
    Best Regards,
    Jambor
    We are trying to better understand customer views on social support experience, so your participation in this interview project would be greatly appreciated if you have time. Thanks for helping make community forums a great place.
    Click
    HERE to participate the survey.

  • Cannot create Azure Service Bus connector

    Hi,
    I tried to create a service bus connector. I did put in the connection string and the name of the queue, validation passed showing a green check. For the rest of the settings I just used default values given. The Create button is still disabled and
    it doesn't give any info as what's missing.
    Thanks,
    Paul

    Hi Paul - could you send us a screenshot of this? We'll take a look
    Thanks,
    Prashant

  • MessagingCommunicationException - Azure service bus

    Quite frequently i see below errors in log files, are these not internally handled by service bus and retry ?. These doesn't seem to be timeout error and according to information from MSDN retry policy is applicable only for transient errors , is below error
    classified as transient error
    Exception: Microsoft.ServiceBus.Messaging.MessagingCommunicationException: Error during communication with Service Bus. Check the connection information, then retry. ---> System.ServiceModel.CommunicationObjectFaultedException: Internal Server Error:
    The server did not provide a meaningful reply; this might be caused by a premature session shutdown..TrackingId:urn:uuid:e5749ef1-9ad3-4543-a420-14dfebaae4c4, Timestamp:3/30/2015 10:37:28 PM
    Server stack trace:
    Exception rethrown at [0]:
       at Microsoft.ServiceBus.Common.AsyncResult.End[TAsyncResult](IAsyncResult result)
       at Microsoft.ServiceBus.Messaging.Sbmp.DuplexRequestBindingElement.DuplexRequestSessionChannel.DuplexCorrelationAsyncResult.End(IAsyncResult result)
       at Microsoft.ServiceBus.Messaging.Channels.ReconnectBindingElement.ReconnectChannelFactory`1.RequestSessionChannel.RequestAsyncResult.<GetAsyncSteps>b__4(RequestAsyncResult thisPtr, IAsyncResult r)
       at Microsoft.ServiceBus.Messaging.IteratorAsyncResult`1.StepCallback(IAsyncResult result)
    Exception rethrown at [1]:
       at Microsoft.ServiceBus.Common.AsyncResult.End[TAsyncResult](IAsyncResult result)
       at Microsoft.ServiceBus.Messaging.Channels.ReconnectBindingElement.ReconnectChannelFactory`1.RequestSessionChannel.EndRequest(IAsyncResult result)
       at Microsoft.ServiceBus.Messaging.Sbmp.RedirectBindingElement.RedirectContainerChannelFactory`1.RedirectContainerSessionChannel.RequestAsyncResult.<>c__DisplayClass17.<GetAsyncSteps>b__a(RequestAsyncResult thisPtr, IAsyncResult r)
       at Microsoft.ServiceBus.Messaging.IteratorAsyncResult`1.StepCallback(IAsyncResult result)
    Exception rethrown at [2]:
       at Microsoft.ServiceBus.Common.AsyncResult.End[TAsyncResult](IAsyncResult result)
       at Microsoft.ServiceBus.Messaging.Sbmp.RedirectBindingElement.RedirectContainerChannelFactory`1.RedirectContainerSessionChannel.EndRequest(IAsyncResult result)
       at Microsoft.ServiceBus.Messaging.Channels.ReconnectBindingElement.ReconnectChannelFactory`1.RequestSessionChannel.RequestAsyncResult.<GetAsyncSteps>b__4(RequestAsyncResult thisPtr, IAsyncResult r)
       at Microsoft.ServiceBus.Messaging.IteratorAsyncResult`1.StepCallback(IAsyncResult result)
    Exception rethrown at [3]:
       at Microsoft.ServiceBus.Common.AsyncResult.End[TAsyncResult](IAsyncResult result)
       at Microsoft.ServiceBus.Messaging.Channels.ReconnectBindingElement.ReconnectChannelFactory`1.RequestSessionChannel.EndRequest(IAsyncResult result)
       at Microsoft.ServiceBus.Messaging.IteratorAsyncResult`1.StepCallback(IAsyncResult result)
    Exception rethrown at [4]:
       at Microsoft.ServiceBus.Common.AsyncResult.End[TAsyncResult](IAsyncResult result)
       at Microsoft.ServiceBus.Messaging.Sbmp.SbmpMessageSender.OnEndClose(IAsyncResult result)
       --- End of inner exception stack trace ---
       at Microsoft.ServiceBus.Common.AsyncResult.End[TAsyncResult](IAsyncResult result)
       at Microsoft.ServiceBus.Messaging.TopicClient.OnEndClose(IAsyncResult result)
       at Microsoft.ServiceBus.Messaging.MessageClientEntity.Close(TimeSpan timeout)
       at Canon.PhotoModel.Infrastructure.ServiceBus.ServiceBusRepository.SendMessage[T](T eventObject, BrokeredMessage message)

    It'll retry until operation timeout duration expires. Let's say the operation timeout on the factory is 60 seconds (this is the deafult value unless you've changed it). In this case the client will retry calls on transient failures internally until 60
    seconds expire, then basically it'll buble up the exception to the caller.

  • Is this the best design for asynchronous notifications (such as email)? Current design uses Web Site, Azure Service Bus Queue, Table Storage and Cloud Service Worker Role.

    I am asking for feedback on this design. Here is an example user story:
    As a group admin on the website I want to be notified when a user in my group uploads a file to the group.
    Easiest solution would be that in the code handling the upload, we just directly create an email message in there and send it. However, this seems like it isn't really the appropriate level of separation of concerns, so instead we are thinking to have a separate
    worker process which does nothing but send notifications. So, the website in the upload code handles receiving the file, extracting some metadata from it (like filename) and writing this to the database. As soon as it is done handling the file upload it then
    does two things: Writes the details of the notification to be sent (such as subject, filename, etc...) to a dedicated "notification" table and also creates a message in a queue which the notification sending worker process monitors. The entire sequence
    is shown in the diagram below.
    My questions are: Do you see any drawbacks in this design? Is there a better design? The team wants to use Azure Worker Roles, Queues and Table storage. Is it the right call to use these components or is this design unnecessarily complex? Quality attribute
    requirements are that it is easy to code, easy to maintain, easy to debug at runtime, auditable (history is available of when notifications were sent, etc...), monitor-able. Any other quality attributes you think we should be designing for?
    More info:
    We are creating a cloud application (in Azure) in which there are at least 2 components. The first is the "source" component (for example a UI / website) in which some action happens or some condition is met that triggers a second component or "worker"
    to perform some job. These jobs have details or metadata associated with them which we plan to store in Azure Table Storage. Here is the pattern we are considering:
    Steps:
    Condition for job met.
    Source writes job details to table.
    Source puts job in queue.
    Asynchronously:
    Worker accepts job from queue.
    Worker Records DateTimeStarted in table.
    Queue marks job marked as "in progress".
    Worker performs job.
    Worker updates table with details (including DateTimeCompleted).
    Worker reports completion to queue.
    Job deleted from queue.
    Please comment and let me know if I have this right, or if there is some better pattern. For example sake, consider the work to be "sending a notification" such as an email whose template fields are filled from the "details" mentioned in
    the pattern.

    Hi,
    Thanks for your posting.
    This development mode can exclude some errors, such as the file upload complete at the same time... from my experience, this is a good choice to achieve the goal.
    Best Regards,
    Jambor  
    We are trying to better understand customer views on social support experience, so your participation in this interview project would be greatly appreciated if you have time. Thanks for helping make community forums a great place.
    Click
    HERE to participate the survey.

  • Error while creating azure service bus connector

    Hi,
    I get below error while creating SB connector-
    {"status":"Failed","error":{"code":"ResourceDeploymentFailure","message":"The resource operation completed with terminal provisioning state 'Failed'."}}
    Screenshot below-

    Unfortunately it still fails with same error. It took quite a long time before failing.
    {"status":"Failed","error":{"code":"ResourceDeploymentFailure","message":"The
    resource operation completed with terminal provisioning state 'Failed'."}}

  • Finding the type of the BrokeredMessage body (Windows Azure Service Bus)

    Hi all
    I was wondering if it is possible to find the type stored in the BrokeredMessage body (payload)? I need the body type prior to calling BrokeredMessage.GetBody<T>().
    Kind regards
    OS

    Instead of using a custom property, another alternate is to use the BrokeredMessage.ContentType property.
    According to the documentation, this is recommended way to indicate the  type of the content of the message body.
    http://msdn.microsoft.com/en-us/library/microsoft.servicebus.messaging.brokeredmessage.contenttype.aspx

  • SB-Messaging and service bus DLL within BTS seems not compatible with Cloud

    I am trying to retreive a message from a Queue in azure service bus. The receive location gets disabled after 5 seconds of enabling it. The error message is :
    The receive location "rlFromFireQueue" with URL "sb://muazure.servicebus.windows.net/firealertqueue" is shutting down. Details:"System.InvalidOperationException: This client is not supported for a partitioned entity. The client version
    should be greater or equal than version '2013-10'..8653aa96-4c37-4ee1-8be8-52f2e9702ee0_G2_G2 ---> System.ServiceModel.FaultException`1[System.ServiceModel.ExceptionDetail]: This client is not supported for a partitioned entity. The client version should
    be greater or equal than version '2013-10'..8653aa96-4c37-4ee1-8be8-52f2e9702ee0_G2_G2
    I had the same exact issue when I was using an old .Net console application which was using microsft.servicebus.dll version 2.1. I downloaded the 2.4 azure sdk and ran setup. After replacing the reference in my console project to the new version I was able
    to send messages to my queue.
    My BTS box is 2013 R2 (upgraded from 2013), I checked the directory C:\Program Files (x86)\Microsoft BizTalk Server 2013, I noticed that the Microsoft.ServiceBus.dll in this directory is version 2.1 which according to a thread in blog is not compatible
    to a new property introduced since last summer ( clients will be updated to support partitioned entities) when creating a new queue using Quick Create.
    So my question is : How can I update the SB-MESSAGING adapter to use a new version to be compatible with this improvments in Azure or more clearly is there any config or procedures to be done to make the bTS 2013R2 adapter compatible with Azure service bus
    partioning feature
    For your reference, here is the url for the blog where I found the information
    http://mindovermessaging.com/2014/06/21/service-bus-queuetopic-partitioning-not-supported-in-biztalk-services/
    Thanks in advance

    I'm afraid you wont be able to update the SB-Messaging adapter because the partitioning option is not supported.
    However you have an alternative:
    You can try using a WCF-Custom port with netMessagingTransport binding. This should be tested, because I'm not 100% sure it supports the partitioning feature. However all necessary features are working because we are using this setup at a current integration
    project.
    Also be sure to check Paolo's blog for all the necessary information regarding configuration and setup: http://code.msdn.microsoft.com/windowsazure/How-to-integrate-BizTalk-f0195690
    Glenn Colpaert - Microsoft Integration MVP - Blog : http://blog.codit.eu

Maybe you are looking for

  • Error 88 or Support Code 88 in Canon Driver printing on art paper from Lightroom

    Re: Error 88 (Support Code 88) of Canon Printer Driver, using Pixma Pro9500 - April 20, 2014 I'm replying to myself from two years ago, and to the rest of you, regarding Error 88.  (My question of April 2012 is in the Photoshop department of Adobe Co

  • Long OLE_FLUSH_CALL times

    Hi there, We use MS Office to view warrants from the document store. Retrieving data from the tender (we use a SAP relevant function) is working fine.We use developed functions to reach these data from the database, required to built up a Word docume

  • How to change color of dotted link box when clicked

    I've been trying to get the dotted red box around a link image of mine to go away. It shows up when you click on the link (yes, even with border set to none in css). But then I realized this only happens when using Firefox. With Safari, when I click

  • ASC2.0 & flash builder 4.7 inconsistencies

    I am trying to upgrade my Ant build script to build my project. First I managed to get the project to build and run fine within flash builder 4.7, fixing the errors that come up. But now when I installed the AIR 3.4 SDK with ASC2.0 and use the ant sc

  • How do I get rid of spinning rainbow wheel without the OS ? Please help

    How do I get rid of spinning wheel without the OS (CD) ?  I live overseas and left it back home in the US. Sincere thanks  you for your help. Desperate Mom!