Examples of createQueue()


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

        try {
            // Create a queue
            System.out.println("Creating a new SQS queue called MyQueue.\n");
            CreateQueueRequest createQueueRequest = new CreateQueueRequest("MyQueue");
            String myQueueUrl = sqs.createQueue(createQueueRequest).getQueueUrl();

            // List queues
            System.out.println("Listing all queues in your account.\n");
            for (String queueUrl : sqs.listQueues().getQueueUrls()) {
                System.out.println("  QueueUrl: " + queueUrl);
View Full Code Here

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

        try {
            // Create a queue
            System.out.println("Creating a new SQS queue called MyQueue.\n");
            CreateQueueRequest createQueueRequest = new CreateQueueRequest("MyQueue");
            String myQueueUrl = sqs.createQueue(createQueueRequest).getQueueUrl();

            // List queues
            System.out.println("Listing all queues in your account.\n");
            for (String queueUrl : sqs.listQueues().getQueueUrls()) {
                System.out.println("  QueueUrl: " + queueUrl);
View Full Code Here

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

      assertEquals(queueList.size(), 0);

        String queueName = QUEUE_PREFIX + randomGenerator.nextLong();
     
      CQSQueue queue = new CQSQueue(queueName, user.getUserId());
      persistence.createQueue(queue);
     
      queueName = QUEUE_PREFIX + randomGenerator.nextLong();
      queue = new CQSQueue(queueName, user.getUserId());
      persistence.createQueue(queue);
View Full Code Here

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

      assertEquals(queueList.size(), 0);

        String queueName = QUEUE_PREFIX + randomGenerator.nextLong();
     
      CQSQueue queue = new CQSQueue(queueName, user.getUserId());
      persistence.createQueue(queue);
     
      queueName = QUEUE_PREFIX + randomGenerator.nextLong();
      queue = new CQSQueue(queueName, user.getUserId());
      persistence.createQueue(queue);
View Full Code Here

Examples of com.gitblit.utils.WorkQueue.createQueue()

  public SshCommandFactory(IGitblit gitblit, IdGenerator idGenerator) {
    this.gitblit = gitblit;

    int threads = gitblit.getSettings().getInteger(Keys.git.sshCommandStartThreads, 2);
    WorkQueue workQueue = new WorkQueue(idGenerator);
    startExecutor = workQueue.createQueue(threads, "SshCommandStart");
    destroyExecutor = Executors.newSingleThreadExecutor(
        new ThreadFactoryBuilder()
          .setNameFormat("SshCommandDestroy-%s")
          .setDaemon(true)
          .build());
View Full Code Here

Examples of com.netflix.astyanax.recipes.queue.MessageQueue.createQueue()

                .withShardLockManager(slm)
                .build();

        scheduler.createStorage();
        Thread.sleep(1000);
        scheduler.createQueue();

        final ConcurrentMap<String, Boolean> lookup = Maps.newConcurrentMap();

        final int batchSize = 50;
View Full Code Here

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

                .withShardCount(1)
                .withPollInterval(100L, TimeUnit.MILLISECONDS)
                .withShardLockManager(slm)
                .build();

        queue.createQueue();
        MessageProducer producer = queue.createProducer();
        MessageConsumer consumer = queue.createConsumer();

        // Enqueue a recurring message
        final String key = "RepeatingMessageWithTimeout";
View Full Code Here

Examples of javax.jms.QueueSession.createQueue()

      connect();

      QueueSession session = queueConnection.createQueueSession(false, Session.AUTO_ACKNOWLEDGE);

      Queue jndiQueue = (Queue) getInitialContext().lookup("queue/testQueue");
      Queue createQueue = session.createQueue(jndiQueue.getQueueName());
      assertTrue("Failed for " + QUEUE_FACTORY, jndiQueue.equals(createQueue));

      getLog().debug("InvalidDestinationTopicSubscriber passed");
   }
View Full Code Here

Examples of javax.jms.Session.createQueue()

    }


    protected void subscribeToQueue(JmsServiceExporter exporter, String queueName) throws JMSException {
        Session serverSession = createSession();
        Queue queue = serverSession.createQueue(queueName);
        MessageConsumer consumer = serverSession.createConsumer(queue);
        consumer.setMessageListener(exporter);
    }

}
View Full Code Here

Examples of javax.jms.Session.createQueue()

    public void testTimeout() throws Exception {
        SingleThreadedRequestor requestor = (SingleThreadedRequestor) createRequestor(getDestinationName());

        Session session = createSession();
        MessageConsumer receiver = session.createConsumer(session.createQueue(getDestinationName()));

        // clear old messages
        while (receiver.receive(1) != null) {
            ;
        }
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.