Examples of QueueInfo


Examples of com.cloudhopper.mq.queue.impl.QueueInfo

  out.println("}");
    }

    private void printHeader(Queue queue) throws IOException {
  out.print("##");
  QueueInfo queueInfo = queueManager.getQueueInfoMap().get(queue.getId());
  out.println(mapper.writeValueAsString(queueInfo));
    }
View Full Code Here

Examples of com.microsoft.windowsazure.services.servicebus.models.QueueInfo

            throws ServiceException {
        Feed feed = listOptions(options,
                getResource().path("$Resources/Queues")).get(Feed.class);
        ArrayList<QueueInfo> queues = new ArrayList<QueueInfo>();
        for (Entry entry : feed.getEntries()) {
            queues.add(new QueueInfo(entry));
        }
        ListQueuesResult result = new ListQueuesResult();
        result.setItems(queues);
        return result;
    }
View Full Code Here

Examples of com.sun.grid.jam.queue.entry.QueueInfo

  private static void addQMaster(RMServer server)
  {
    try {
      Entry[] attrQueue = {
        new Name(SGEQueue.QMASTER_NAME),
        new QueueInfo(SGEQueue.QMASTER_NAME,
                      QueueStatus.QUEUE_ENABLED,
                      new Boolean(true), // interactive
                      new Boolean(true), // batch
                      Boolean.FALSE, // dedicated
                      server.rmsName),
View Full Code Here

Examples of com.sun.grid.jam.queue.entry.QueueInfo


      try {
        Entry[] attrQueue = {
          new Name(queue.getName()),
          new QueueInfo(queue.getName(),
                        new QueueStatus(queue.getState()),
                        new Boolean(queue.isInteractive()), // interactive
                        new Boolean(queue.isBatch()), // batch
                        Boolean.FALSE, // dedicated
                        server.rmsName),
View Full Code Here

Examples of com.sun.grid.jam.queue.entry.QueueInfo

  private QueueInfo queueParams;
   
  public AppParams()
  {
    computeParams = new ComputeInfoParams();
    queueParams = new QueueInfo();
  }
View Full Code Here

Examples of net.greghaines.jesque.meta.QueueInfo

            exactly(2).of(jedis).type(queueKey); will(returnValue(KeyType.ZSET.toString()));
            oneOf(jedis).zcard(queueKey); will(returnValue(size));
            oneOf(jedis).zrange(queueKey, jobOffset, jobOffset + jobCount - 1); will(returnValue(payloads));
            oneOf(pool).returnResource(jedis);
        }});
        final QueueInfo queueInfo = this.qInfoDAO.getQueueInfo(name, jobOffset, jobCount);
        Assert.assertNotNull(queueInfo);
        Assert.assertEquals(name, queueInfo.getName());
        Assert.assertEquals((Long) size, queueInfo.getSize());
        final List<Job> jobs = queueInfo.getJobs();
        Assert.assertNotNull(jobs);
        Assert.assertEquals(payloads.size(), jobs.size());
    }
View Full Code Here

Examples of net.lr.karaf.jms.service.QueueInfo

        table.header.add("Name");
        table.header.add("Messages");
        List<String> queues = this.jmsService.listQueues();
        for (String name : queues) {
            List<String> row = table.addRow();
            QueueInfo qi = jmsService.getQueueInfo(name);
            row.add(name);
            row.add("" + qi.getNumPendingMessages());
        }
        table.print();
        return null;
    }
View Full Code Here

Examples of net.lr.karaf.jms.service.QueueInfo

        });
    }

    @Override
    public QueueInfo getQueueInfo(String queueName) {
        QueueInfo qi = new QueueInfo();
        qi.setName(queueName);
        qi.setNumPendingMessages(getMessagesInQueue(queueName));
        return qi;
    }
View Full Code Here

Examples of org.apache.hadoop.mapreduce.QueueInfo

   * @throws IOException
   */
 
  public JobStatus[] getJobsFromQueue(final String queueName) throws IOException {
    try {
      QueueInfo queue = clientUgi.doAs(new PrivilegedExceptionAction<QueueInfo>() {
        @Override
        public QueueInfo run() throws IOException, InterruptedException {
          return cluster.getQueue(queueName);
        }
      });
      if (queue == null) {
        return null;
      }
      org.apache.hadoop.mapreduce.JobStatus[] stats =
        queue.getJobStatuses();
      JobStatus[] ret = new JobStatus[stats.length];
      for (int i = 0 ; i < stats.length; i++ ) {
        ret[i] = JobStatus.downgrade(stats[i]);
      }
      return ret;
View Full Code Here

Examples of org.apache.hadoop.mapreduce.QueueInfo

   * @return Queue information associated to particular queue.
   * @throws IOException
   */
  public JobQueueInfo getQueueInfo(final String queueName) throws IOException {
    try {
      QueueInfo queueInfo = clientUgi.doAs(new
          PrivilegedExceptionAction<QueueInfo>() {
        public QueueInfo run() throws IOException, InterruptedException {
          return cluster.getQueue(queueName);
        }
      });
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.