SMQS - deregistration of single queue

Hi,
This is in CRM 5.0.
We can deregister a desination in SMQS. For example, if we deregister R3 destination in SMQS, all queues going to R3 will be blocked.
What I want to do is, deregister only one particular queue for a single R/3 customer (let's say R3AUBUPA1234567890), so that only changes made to that particular BP are blocked, and all other queues going from CRM to R/3 remains unblocked.
I need to do this so that I can debug changes to this one BP and rest of the production environment remains unaffected. If I block the R/3 destination, all data going from CRM to R/3 will be blocked.
Any idea how to achieve this in 5.0? I know it was easily done in SMQS in 3.0. But somehow, I haven't been able to manage it in 5.0.
Regards,
Kaushal

Kaushal,
The only idea I have off hand is you could deregister the inbound queues on the R/3 side.  You could use SMQR on the R/3 side to deregister the queue.
Take care,
Stephen

Similar Messages

  • Single queue: concurrent processing of messages in multiple consumers

    Hi,
    I am new to jms . The goal is to  process messages concurrently from a queue in an asynchronous listener's onMessage method  by attaching a listener instance to multiple consumer's with each consumer using its own session and running in a separate thread, that way the messages are passed on to the different consumers for concurrent processing. 
    1) Is it ossible to process messsages concurrently from a single queue by creating multiple consumers ?
    2)  I came up with the below code, but would like to get your thoughts on whether the below code looks correct for what I want to accomplish.  
    import java.io.IOException;
    import java.io.InputStreamReader;
    import java.util.Properties;
    import javax.jms.Connection;
    import javax.jms.ConnectionFactory;
    import javax.jms.Destination;
    import javax.jms.JMSException;
    import javax.jms.Message;
    import javax.jms.MessageConsumer;
    import javax.jms.MessageListener;
    import javax.jms.Session;
    import javax.jms.TextMessage;
    import org.slf4j.Logger;
    import org.slf4j.LoggerFactory;
    import com.walmart.platform.jms.client.JMSConnectionFactory;
    public class QueueConsumer implements Runnable, MessageListener {
      public static void main(String[] args) {
       // Create an instance of the client
        QueueConsumer consumer1 = new QueueConsumer();
        QueueConsumer consumer2 = new QueueConsumer();
        try {
        consumer1.init("oms","US.Q.CHECKOUT-ORDER.1.0.JSON");   //US.Q.CHECKOUT-ORDER.1.0.JSON   is the queue name
        consumer2.init("oms","US.Q.CHECKOUT-ORDER.1.0.JSON");
        }catch( JMSException ex ){
        ex.printStackTrace();
        System.exit(-1);
        // Start the client running
        Thread newThread1 = new Thread(consumer1);
        Thread newThread2 = new Thread(consumer1);
        newThread1.start();newThread2.start();
        InputStreamReader aISR = new InputStreamReader(System.in);
              char aAnswer = ' ';
              do {
                  try {
      aAnswer = (char) aISR.read();
    catch (IOException e)
      // TODO Auto-generated catch block
      e.printStackTrace();
    } while ((aAnswer != 'q') && (aAnswer != 'Q'));
              newThread1.interrupt();
              newThread2.interrupt();
              try {
      newThread1.join();newThread2.join();
      } catch (InterruptedException e) {
      // TODO Auto-generated catch block
      e.printStackTrace();
              System.out
      .println("--------------------exiting main thread------------------------"+Thread.currentThread().getId());
            System.exit(0);
    // values will be read from a resource properties file
    private static String connectionFactoryName = null;
    private static String queueName = null;
    // thread safe object ref
      private static ConnectionFactory qcf = null;
      private static Connection queueConnection = null;
    // not thread safe
      private Session ses = null;
      private Destination queue = null;
      private MessageConsumer msgConsumer = null;
      public static final Logger logger = LoggerFactory
      .getLogger(QueueConsumer.class);
      public QueueConsumer() {
      super();
      public void onMessage(Message msg) {
      if (msg instanceof TextMessage) {
      try {
      System.out
      .println("listener is "+Thread.currentThread().getId()+"--------------------Message recieved from queue is ------------------------"
      + ((TextMessage) msg).getJMSMessageID());
      } catch (JMSException ex) {
      ex.printStackTrace();
      public void run() {
      // Start listening
      try {
      queueConnection.start();
      } catch (JMSException e) {
      e.printStackTrace();
      System.exit(-1);
      while (!Thread.currentThread().isInterrupted()) {
      synchronized (this) {
      try {
      wait();
      } catch (InterruptedException ex) {
      break;
      * This method is called to set up and initialize the necessary Session,
      * destination and message listener
      * @param queue2
      * @param factoryName
      public void init(String factoryName, String queue2) throws JMSException {
      try {
      qcf = new JMSConnectionFactory(factoryName);
      /* create the connection */
      queueConnection = qcf.createConnection();
      * Create a session that is non-transacted and is client
      * acknowledged
      ses = queueConnection.createSession(false,
      Session.CLIENT_ACKNOWLEDGE);
      queue = ses.createQueue(queue2);
      logger.info("Subscribing to destination: " + queue2);
      msgConsumer = ses.createConsumer(queue);
      /* set the listener  */
      msgConsumer.setMessageListener(this);
      System.out.println("Listening on queue " +queue2);
      } catch (Exception e) {
      e.printStackTrace();
      System.exit(-1);
      private static void setConnectionFactoryName(String name) {
      connectionFactoryName = name;
      private static String getQueueName() {
      return queueName;
      private static void setQueueName(String name) {
      queueName = name;

    Hi Mark,
    if the messages are sent with quality of service EO (=exactly once) you can add queues.
    From documentation:
    Netweaver XI -> Runtime -> Processing xml messages -> Queues for asynchronous message processing
    ...For incoming messages you set the parameter EO_INBOUND_PARALLEL from the Tuning category.
    If more than one message is sent to the same receiver, use the configuration parameter EO_OUTBOUND_PARALLEL of the Tuning category to process messages simultaneously in different queues.
    Transaction: SXMB_ADM
    Regards
    Holger

  • Multiple queue vs single queue - peformance

    Hi All,
    Could pls throw some light on the following design.
    Currenty, We have more than 100 queues and for each there is a different MDB to receive the message.Now, somehow we made a single instance of same MDB listen to all these queues by looking at the input message. The requiement now is, is it possible to club all the queues into single queue as it's asynchronous messaging. The receiver may also try write into the same queue at the end of message processing.If so, how would be performance. Is this performance better than having multiple queues?.
    The message are expecting to be 25 k/day in the queue. And we are using Weblogic server.
    Please let me know if you need more details.
    Thanks
    Srinath

    You could try to use selectors to assign messages to particular MDBs. This way you off load some of the work on the broker but selectors by their nature usually have an impact on broker's performance. It all depends on your application, your expectations, size and the rate of your messages, how long it takes to process them on the client side. There is no simple answer in this case. You would have to test some scenarios to come up with a best solution that fits your requirements. Having said that I personally believe that some degree of partitioning of your queue could be beneficial. On a heavily loaded system it may increase the concurrency of the system and its resilience, particularly if you place the queues in different brokers. Try to imagine your broker as if it was a DB server with just one table (I'm not sure if this is the best analogy but I can't think about anything else at the moment).

  • Single Queue Vs Multiple Queues

    Hi,
    I am in the process of architecting some queues between remote databases. There are different document types being propagated from one queue to another, and they have different priorities. At the end queue there are multiple processes to dequeue and action the different document types.
    My question is, is it better to have one end queue for each process/document type ( ie multiple end point queues), or one single end point queue with all the documents in them regardless of the type?
    I know that it is possible to have the single queue end point, but is this the best option and why?
    Thanks,
    matt

    Hi Peter,
    What do you mean by different document type?Document content only is different. The payload will be the same. All the documents will be passed through as blobs. The payload will have a field to define the document content type.
    Do you intend to store different message types in the same source queue?At this stage we can go either way. If we have one single end point queue we will more than likely have one single source queue.
    If so what is the definition of the payload? The payload definition will be the same in all cases, both source and destination.
    What version of databases are you propagating between?10.2
    How many dequeueing processes will you have at the remote end?One program for each of the different document content type (invoices, remittance, etc.). Initially there will be 4, but this is likely to grow to 12 or more.
    Ultimately we expect around 10,000 documents per day to pass through the system.
    Thanks,
    Matt

  • JMS Queue - 2 Consumers from single Queue

    Hi,
    I have a scenario like, there is a single which has records. Of which some records need to be send to 1 application and some records need to be sent to anothere appln.
    So, there are two consumers for this Queue.
    How to implement this in SOA?
    Is selecting the data based on a flag possible?
    Thanks,
    Priya

    You can use Message Selectors for this. Please refer the below link
    SOA 11g- Message Selector Property in JMS Adapter - Oracle Fusion Middleware Blog

  • How to create Single Queue for more than one interfaces(XI)

    Hi Experts,
    I want to set up a separate queue for 3 interfaces which all are outbound IDOC to FTP.
    Please let me know ' Hhow to create a queue for multiple interfaces with Quality of Service 'EO''.
    Thanks,
    Srinivas P.

    The same reason that Apple and 3rd Party vendors put multi-size templates in one file I expect. I am trying to construct an in-house standard template for use in our company, and it is easier to manage if there is only one file to send to people rather than many - both initially and for subsequent edits / updates to the template.
    Of course it would be possible to create several templates (one for each size). But since it is clear that templates can be combined, it appears sensible to do this - unless the doing of it is horridly complicated

  • Multiple Notifications enqueued on single queue not dequeued concurrently

    Hi,
    Oracle 10G database AQ behavior (10.2.0.4.0)
    1) Enqueued 5 notifications into Oracle AQ
    2) 5 Jobs are being submitted in dba_jobs in different Sessions
    3) All 5 notifications are dequeued by Callback procedure in Parallel sessions
    Oracle 11G database AQ behavior (11.2.0.3.0)
    1) Enqueued 5 notifications into Oracle AQ
    2) 1 Job is being submitted in dba_scheduler_jobs
    3) 5 notifications are being dequeued by Callback procedure in single session
    Is there a way to Dequeue messages concurrently in parallel sessions?
    Thanks
    Sridhar

    Hi Peter,
    Throughput has been decreased after moving to 11G.
    Background of code:
    Call back procedure on AQ we have consists of two parts
    1) Dequeue of first message available
    2) Calling an another procedure with information from Notification. This procedure processed all records satisfying the information from Notification.
    It takes around 6 minutes to process
    We have parameter p_var which is configured as 6 and this controls number of dbms_jobs fired as below
    LOOP
    FOR i in 1..p_var
    LOOP
    dbms_lock.allocate_unique ('QUEUE1'||i,l_lckhandle_db);
    l_rel := dbms_lock.request (l_lckhandle_db, 6, 1, FALSE);
    EXIT WHEN l_rel = 0;
    END LOOP;
    IF l_rel <> 0
    THEN
    dbms_lock.sleep (10);
    END IF;
    EXIT WHEN l_rel = 0;
    END LOOP;
    Suppose we have 10 Notifications enqueued in same second in AQ
    10G code flow:
    1) 6 jobs were fired and processing was in 6 parallel sessions
    11G code flow:
    1) only one scheduler job is fired and all 10 notifications are processed in serial.
    This is reason for less throughput in 11G.
    Do we have any way we can make this process in parallel? (not enqueing notifications in same second and changing any DB level parameter?)
    I have an idea to fire a separate dbms_job or scheduler job to process part 2 of callback procedure.
    Is this solution we can consider to problem we have or is there any other solution?
    Thanks
    Sridhar

  • Weblogic JMS single vs multiple Queues

    I am building an application which acts as an event listener and based on the events received it needs to execute certain steps or work-flow. Is it better to have events posted to a single queue and MDB invoking different business logic components based on event type or to have one queue per event type and the corresponding MDBs invoke different business logic ? Our assumption is that a heavy workflow corresponding to a particular event will not starve the performance of other light weight events since they are processed in separate queues.
    Your suggestions please.

    Will I get an increased throughput by having heavy weight events processed in different queue instead of having one >queue / MDB for the complete set ?In general it is a good idea to have separate set of the Queue/MDB to support completely different business logic and different message types so you can tune destination and MDB pool size as per it's own concurrent processing requirements. With it's own set of Queue/MDB per business logic it will definitely help to achieve better parallel processing. Throughput also depends transaction boundaries at MDB side. For a given queue, JMS server will not deliver next message until current message is processed successfully and received acknowledgment.
    If threads get stuck with the heavy weight event processing, is it still going to affect the events processed at other queues ?In general consumers(including MDB) for each destinations execute in separate thread in parallel. So stuck thread with one kind of consumer does not impact consumers on different destination, however if problem persist and high number of messages results in high number of stuck threads it will definitely starve WebLogic thread resources and cause negative impact on WebLogic system itself. One way to limit damage of the stuck thread is by limiting pool size of the individual MDB.
    Hope this will help.
    jayesh@yagnasys

  • SMQS scheduler: Queues stuck / block situation

    Hi All
    we have a Q stuck situation in ECC6.0 (ISU) with the Q name R3AUBUPA*, destination CRM, has status RUNNING. The implication of this is all other Q's get blocked and the this impacts the business operation. Currently we unregister and register the Q's and this clears the blocked Q and the backlogs.
    1) The question is anybody aware of a know issue on SMQS or is there a setting / parameter that needs to be set/unset or parameter values that needs tweaking.
    2) Also currently we have a dedicated resource to minitor this and address the issue, wonder if anyone has setup an alert in this context ?
    Note -
    a) All Q's are registered
    b) Except for the workflow Q's all are type 3 connections.
    c) the Q's are not confined to a server as that is not an option the client desires.
    Regards
    Srikanth

    Hello Srikanth,
    Txn:SMQS is used to de-rgister or register the destination.If you dereister/register a destination  then  data will not/will to that
    destination.
    You can go through the below set of notes for more details on queue hanlding and SMQS.
    685366          Welche Queues sollen in einem CRM System registriert werden?
    764081          CRM or R3 Backend is temporarily shut down
    356228          qRFC occupies all work processes on the R/3 backend or the C
    574774          Outbound queues hang in status STOP
    564435          Additional information on CRM System copy
    515579                          Customer message in the area: CRM-MW-COM
    480543          CRM MW R&R queues in status STARTING (no processing)
    580487          Guidelines for deactivating the mass queues CSA_MASS_BUPA
    777965          Flow Debugging information through queues
    Hope thils helps.
    Best Regards,
    Shanthala Kudva

  • Queues in READY status for no apparent reason

    Dear All,
    This question has been posted many times but never saw a conclusive answer on this forum.
    To repeat, I see queues being built in READY status in APO inbound for no apparent reason.
    All settings of scheduler being fine (SMQS - Type R), there are large number of queues awaiting to be manually unlocked from READY status and they get cleared on unlock. There are no waiting queues but still entries in say an update of a stock queue are like 70+. I am able to clear them manually but that would be stupidity when I am talking of 30K queues build up thus.
    Its not that not a single queue is moving. Some are getting processed (RUNNING) on their own but thats at snails speed as compared to the queues in READY.
    I have scheduled the report /SAPAPO/RCIFRESTART that seems to have scheuled something in the background but I cant trace that job.
    Please help.
    Regards,
    Loknath

    Loknath,
    If you have 'many' queues 'RUNNING' for a long period of time, LUWs that are inline behind them will eventually stop trying.  You can restart these queues with the /SAPAPO/RCIFRESTART program mentioned above.
    There are lots of ways to tune queues to meet business requirements.  Speak to your local CIF expert.
    Some people use a job to run /SAPAPO/RCIFRESTART  on a regular schedule.  I have seen a system where this job is scheduled to run hourly.
    30K queues is not really reasonable.  If you always have this backlog, then there is a performance issue that needs to be addressed (SCM is not able to process the data as fast as ECC is sending).  If this is a startup, then you just have to be patient.  Initial loads can sometimes take days to fully clear all queues, especially if the SCM is sized a bit on the small side.  Continue restarting until you have cleared all queues, then see if they begin to build again.
    Best Regards,
    DB49

  • Queues in READY status

    Dear All,
    This question has been posted many times but never saw a conclusive answer on this forum.
    To repeat, all settings of scheduler being fine (SMQS - Type R), there are large number of queues awaiting to be manually unlocked from READY status to clear them. There are no waiting queues but still entries in say an update of a stock queue are like 70+ in READY status. I am able to clear them manually but that would be stupidity when I am talking of 30K queues build up thus in READY status. Its not that not a single queue is moving. Some are getting processed (RUNNING) on their own but thats insignificant as compared to the queues in READY and also pathetically time consuming.
    I have scheduled the report /SAPAPO/RCIFRESTART that seems to have scheuled something in the background but I cant trace that job.
    Please help.
    Regards,
    Loknath

    Loknath,
    If you have 'many' queues 'RUNNING' for a long period of time, LUWs that are inline behind them will eventually stop trying.  You can restart these queues with the /SAPAPO/RCIFRESTART program mentioned above.
    There are lots of ways to tune queues to meet business requirements.  Speak to your local CIF expert.
    Some people use a job to run /SAPAPO/RCIFRESTART  on a regular schedule.  I have seen a system where this job is scheduled to run hourly.
    30K queues is not really reasonable.  If you always have this backlog, then there is a performance issue that needs to be addressed (SCM is not able to process the data as fast as ECC is sending).  If this is a startup, then you just have to be patient.  Initial loads can sometimes take days to fully clear all queues, especially if the SCM is sized a bit on the small side.  Continue restarting until you have cleared all queues, then see if they begin to build again.
    Best Regards,
    DB49

  • Multiple consumers of the same Queue

    In the past my use of JMS queues has been limited to a single message producer and a single consumer. I am now looking at having multiple copies of the same consumer running for load balancing and failover purposes, and this leads me to what I think is a basic question. BTW, we're running OpenMQ 4.4u1.
    I have messages being produced and saved in a single queue.
    I then have a consumer program whose logic is something like this:
    1. Create session with no transaction and CLIENT_ACKNOWLEDGE.
    2. Receive message from queue.
    3. Do some processing with message. Repeat processing attempts multiple times, if needed, until successful.
    4. Once processing is successful, acknowledge message.
    Assume that I am running multiple copies of the consumer in separate JVMs (or on separate servers, for that matter).
    Here are my related questions.
    1. If step 3 takes a long time (e.g., several minutes) can I be sure that only one instance of the consumer will receive the message?
    2. If a consumer is in step 3 and a catastrophic failure occurs (e.g., the JVM or server it is running on crashes) the message will never be acknowledged, but the session will not be shut down in an orderly fashion, either. Will the message that was received but never acknowledged eventually be delivered to another copy of the consumer?
    3. If step three takes a very long time (hours or days, rather than minutes), will the broker misinterpret this as a failure of the consumer and deliver the same message to another one of the consumers?
    Thank you for reading and/or responding to this question.
    Bill

    1. If step 3 takes a long time (e.g., several minutes) can I be sure that only one instance of the consumer will receive the message?A queue message will only be delivered and consumed by 1 consumer.
    2. If a consumer is in step 3 and a catastrophic failure occurs (e.g., the JVM or server it is running on crashes) the message will never be acknowledged, but the session will not be shut down in an orderly fashion, either. Will the message that was received but never acknowledged eventually be delivered to another copy of the consumer?Yes.
    3. If step three takes a very long time (hours or days, rather than minutes), will the broker misinterpret this as a failure of the consumer and deliver the same message to another one of the consumers?No, as long as the consumer's Session or Connection are intact

  • How do I set the delivery policy for a queue in iMQ 2.0?

    The list on page 67 of the 2.0 administration guide appears to be
    incomplete. Specifically, I'm interested in knowing how to set
    the default delivery policy for a Queue through the jmqobjmgr command.
    I need the valid attribute name to pass in to jmqobjmgr.

    The "queueDeliveryPolicy" is an attribute of a queue
    created in the broker - not in the administered object
    destination so that is why you are not seeing that
    attribute on the list on page 67.
    By default, the broker by will use the "single" queue delivery
    policy unless you choose to change the values of the property
    "jmq.queue.defaultdeliveryPolicy" to SINGLE, ROUND-ROBIN, or
    FAILOVER. If you would like to do this, see the Chapter 4
    in the admin guide on "Starting and Configuring the Broker".
    It may be easier to set the delivery policy for just one queue.
    To do this, you can use the following command:
    jmqcmd create dst -n myQueue -t q -o "queueDeliveryPolicy=f"
    where valid values to queueDeliveryPolicy is f, s, r.
    You can do a 'jmqcmd -H' to get more info on queue attributes or
    see Chapter 6 in the admin guide on "Creating and Destroying Destinations".

  • Getting error while opening transactions in a perticular queue

    Hi All,
    we had been experiencing this error for some days now. When we try to open any transactions in this queue we end up getting the below error:
    "Access denied.
    You may not have access to perform this task on the chosen person
    or your session has timed out. (Try to log into the system again.)
    I have complte access to this - so that should be an issue. When i try to open a transaction it is long time to process and then i end up with this error.
    I heard in other post to minimise the search attributes for this and i did the same but it worked for some time and then again i am getting the same error.
    Please suggest how to get rid of this. This is right now happening only to one single queue.

    Hi,
    According to your post, my understanding is that you got the error while opening a document in SharePoint library.
    The issue can occur when you have several different versions of Office installed on the same computer and you have
    several different versions of the OWSSUPP DLL available which are not registered correctly.
    To resolve this issue you should disable Microsoft SharePoint Foundation Support in any other version of Office installed on the machine and then repair Office.
    For more information: you can refer to:
    You get an error message when you open an Office file from SharePoint on a computer on which you installed more than one version of Office
    In addition, please ensure that you are using Internet Explorer (32 bit) not the Internet Explorer (64-bit).
    Please Verify the “Sharepoint OpenDocuments Class” addon is installed and enabled. If it is not reinstall Office.
    Please refer to:
    Solved: The document could not be opened for editing. A Microsoft SharePoint Foundation compatible application could not be found to edit the document.
    And, if the Office tools can’t install correctly will also cause the error.
    Here is a thread about this issue, you can check it. The replies include most of the possible reasons and gave the solutions.
    http://social.msdn.microsoft.com/Forums/en-US/06a4943a-5150-44c5-ae6b-3354c85396f5/the-document-could-not-be-opened-for-editing-a-microsoft-sharepoint-foundation-compatible
    Best Regards,
    Linda Li
    Linda Li
    TechNet Community Support

  • Best Practice when deploying a single mdb into a cluster

    At a high level, we are converting all of our components to Weblogic processes that use Stateless Session Beans and Message Driven Beans. All of the weblogic processes will be clustered, and all of the topic queues will be distributed (Uniform Distributed Topics / Queues).
              We have one component that is a single MDB reading from a single queue on 1 machine. It is a requirement that the JMS messages on that queue be processed in order, and the processing of messages frequently requires that the same row in the DB be updated. Does anyone have any thoughts on the best design for that in our clustered environment?
              One possible solution we have come up with (not working):
              Possible Solution 1: Use a distributed topic and enforce a single client via client-id on the connection factory, causing a single consumer.
              1.Deploy a uniform-distributed Topic to the cluster.
              2.Create a connection factory with a client-id.
              3.Deploy a single FooMDB to the cluster.
              Problem with Solution 1: WL allows multiple consumers on Topic with same client-id
              1.Start (2) servers in cluster
              2.FooMDB running on Server_A connects to Topic
              3.FooMDB running on Server_B fails with unique id exception (yeah).
              4.Send messages - Messages are processed only once by FooMDB on Server_A (yeah).
              5.Stop Server_A.
              6.FooMDB running on Server_B connects automatically to Topic.
              7.Send messages - Messages are processed by FooMDB on Server_B (yeah).
              8.Start Server_A
              9.FooMDB successfully connects to Topic, even though FooMDB on Server_B is already connected (bad). Is this a WL bug or our config bug??
              10.Send messages - Messages are processed by both FooMDB on Server_A and Server_B (bad). Is this a WL bug or our config bug??
              Conclusion: Does anyone have any thoughts on the best design for that in our clustered environment? and if the above solution is doable, what mistake might we have made?
              Thank you in advance for your help!
              kb

    Thanks for the helpful info Tom.
              Kevin - It seems that for both the MDB, and the JMS provider, there are (manual or scripted) actions to be taken during any failure event + failure probes possibly required to launch these actions...?
              In the case of the JMS provider, the JMS destination needs to be migrated in the event of managed-server or host failure; if this host is the one that also runs the Admin server then the Admin server also needs to be restarted on a new host too, in order that it can become available to receive the migration instructions and thus update the config of the managed server which is to be newly targetted to serve the JMS destination.
              In the case of the MDB, a deployment action of some sort would need to take place on another managed-server, in the event of a failure of the managed server or the host, where the original MDB had been initally deployed.
              The JMS Destination migration actions can be totally avoided by the use of another JMS implementation which has a design philosophy of "failover" built into it (for example, Tibco EMS has totally automatic JMS failover features) and could be accessed gracefully by using Weblogic foreign JMS. The sinlge MDB deployed on one of the Weblogic managed servers in the cluster would still need some kind of (possibly scripted) redeployment action, and on top of this, there would need to be some kind of health check process to establish if this re-deployment action was actually required to be launched. It is possible that the logic and actions required just to establish the true functional health of this MDB could themsevles be as difficult as the original design requirement :-)
              All of this suggests that for the given requirement; the BEA environment is not well suited; and if no other environment or JMS provider is available at your site, then a manipulation of process itself may be required to enable it to be handled in a highly-available way which can be gracefully administered in a Weblogic cluster.
              We have not discussed the message payload design and the reasons that message order must be respected - by changing the message payload design and possibly adding additional data, this requirement "can", "in certain circumstances", be avoided.
              If you can't do that, I suggest you buy a 2 node Sun Cluster with shared HA storage and use this to monitor a simple JMS client java program that periodically checks for items on the Queue. The Tibco EMS servers could also be configured on this platform and give totally automatic failover protection for both process and host failure scenarios. With the spare money we can go to the pub.
              P.S. I don't work for Tibco or Sun and am a BIG Weblogic fan :-)

Maybe you are looking for

  • PO creation using LSMW through batch input method

    Hi, I am new to working with LSMW and i have completed a project for creating purchase orders using the direct data input method. I need to do the same using batch input method, however in the maintain structure relationship step, it is only allowing

  • What is the difference between the two?

    Hi Friends, Though I know it would be a strange one for many of you,I would like to clarify myself with this. 1) select * from scott.emp order by 8Execution plan for 1) Execution Plan    0      SELECT STATEMENT Optimizer=ALL_ROWS (Cost=3 Card=14 Byte

  • How to get the own schema data while calling the other schema's Procedure

    Hello Experts, I'm Sanjit, new to OTN forum. I'm using Oracle 10g 10.1.0.2.0 database. Another user Sush has created one procedure proc_1 like create or replace procedure proc_1 as v_total number; begin select sum(amt) into v_total from trans_master

  • Creating a new Toolbar

    Hello, I am new to the RoboHelp world, but I am a Programmer by nature. I would like to know if I can create a toolbar for RoboHelp so that I can pre-load it with my own formatting and tags for Paragraphs, Tables, Headings, etc. I have to make it as

  • Web service call "getAllServiceNames"

    var oListURL = "http://localhost:3612/WebSite18/Service.asmx?WSDL"; var e; try xfa.host.messageBox("starting List Retrieval."); var service = SOAP.connect(oListURL); if (typeof service != "object") xfa.host.messageBox("Couldn't get List object."); if