Examples of deleteQueue()


Examples of com.amazonaws.services.sqs.AmazonSQS.deleteQueue()

            String messageRecieptHandle = messages.get(0).getReceiptHandle();
            sqs.deleteMessage(new DeleteMessageRequest(myQueueUrl, messageRecieptHandle));

            // Delete a queue
            System.out.println("Deleting the test queue.\n");
            sqs.deleteQueue(new DeleteQueueRequest(myQueueUrl));
        } catch (AmazonServiceException ase) {
            System.out.println("Caught an AmazonServiceException, which means your request made it " +
                    "to Amazon SQS, but was rejected with an error response for some reason.");
            System.out.println("Error Message:    " + ase.getMessage());
            System.out.println("HTTP Status Code: " + ase.getStatusCode());
View Full Code Here

Examples of com.amazonaws.services.sqs.AmazonSQSClient.deleteQueue()

            String messageRecieptHandle = messages.get(0).getReceiptHandle();
            sqs.deleteMessage(new DeleteMessageRequest(myQueueUrl, messageRecieptHandle));

            // Delete a queue
            System.out.println("Deleting the test queue.\n");
            sqs.deleteQueue(new DeleteQueueRequest(myQueueUrl));
        } catch (AmazonServiceException ase) {
            System.out.println("Caught an AmazonServiceException, which means your request made it " +
                    "to Amazon SQS, but was rejected with an error response for some reason.");
            System.out.println("Error Message:    " + ase.getMessage());
            System.out.println("HTTP Status Code: " + ase.getStatusCode());
View Full Code Here

Examples of com.comcast.cqs.persistence.CQSQueueCassandraPersistence.deleteQueue()

      assertTrue(queue4.getPolicy().equals("no"));
     
      queueList = persistence.listQueues(user.getUserId(), null, false);
     
      for(CQSQueue queue_: queueList) {
        persistence.deleteQueue(queue_.getRelativeUrl());
      }
     
    } catch (PersistenceException e) {
      fail("Test failed:" +  e.toString());
    }   
View Full Code Here

Examples of com.comcast.cqs.persistence.ICQSQueuePersistence.deleteQueue()

        ICQSQueuePersistence persistence = new CQSQueueCassandraPersistence();
   
    List<CQSQueue> queueList = persistence.listQueues(user.getUserId(), null, false);
   
    for (CQSQueue queue: queueList) {
      persistence.deleteQueue(queue.getRelativeUrl());
    }
    }
 
  @Test
  public void testCreateListDeleteQueue() {
View Full Code Here

Examples of com.kurento.kmf.rabbitmq.manager.RabbitManager.deleteQueue()

  public void init() throws IOException {

    RabbitManager manager = new RabbitManager();

    try {
      manager.deleteQueue(RabbitMqManager.PIPELINE_CREATION_QUEUE);
      log.info("Queue '{}' deleted",
          RabbitMqManager.PIPELINE_CREATION_QUEUE);
    } catch (No2xxOKStatusResponseException e) {
      log.info("Queue '{}' doesn't exist",
          RabbitMqManager.PIPELINE_CREATION_QUEUE);
View Full Code Here

Examples of com.netflix.astyanax.recipes.queue.ShardedDistributedMessageQueue.deleteQueue()

                .withStats(stats)
                .withShardCount(1)
                .withPollInterval(100L, TimeUnit.MILLISECONDS)
                .withShardLockManager(slm)
                .build();
        scheduler.deleteQueue();
        scheduler.createQueue();

        MessageProducer producer = scheduler.createProducer();

        // Add a batch of messages and peek
View Full Code Here

Examples of org.apache.qpid.management.common.mbeans.ManagedBroker.deleteQueue()

     */
    public void deleteQueue(String virtualHostName, String queueName)
            throws IOException, JMException, MBeanException
    {
        ManagedBroker managedBroker = getManagedBroker(virtualHostName);
        managedBroker.deleteQueue(queueName);
    }

    /**
     * Sets the logging level.
     *
 
View Full Code Here

Examples of org.apache.qpid.management.common.mbeans.ManagedBroker.deleteQueue()

        _jmxUtils.createQueue("test", getName(), null, false);

        ManagedBroker managedBroker = _jmxUtils.getManagedBroker("test");

        managedBroker.deleteQueue(getName());

        List<String> results = waitAndFindMatches("QUE-1002");

        assertEquals("More than one queue deletion found", 1, results.size());
View Full Code Here

Examples of org.apache.qpid.management.common.mbeans.ManagedBroker.deleteQueue()

                                       autoDelete, exclusive);

        // Clean up
        ManagedBroker managedBroker =
                _jmxUtils.getManagedBroker(VIRTUALHOST_NAME);
        managedBroker.deleteQueue(queueName);
    }

    /**
     * Test that a durable queue can be created via AMQP.
     *
 
View Full Code Here

Examples of org.apache.qpid.management.common.mbeans.ManagedBroker.deleteQueue()

                                       autoDelete, exclusive);

        // Clean up
        ManagedBroker managedBroker =
                _jmxUtils.getManagedBroker(VIRTUALHOST_NAME);
        managedBroker.deleteQueue(queueName);
    }


    /**
     * Test that a transient queue can be created via JMX.
View Full Code Here
TOP
Copyright © 2018 www.massapi.com. All rights reserved.
All source code are property of their respective owners. Java is a trademark of Sun Microsystems, Inc and owned by ORACLE Inc. Contact coftware#gmail.com.