类org.apache.hadoop.mapreduce.QueueInfo源码实例Demo

下面列出了怎么用org.apache.hadoop.mapreduce.QueueInfo的API类实例代码及写法,或者点击链接到github查看源代码。

源代码1 项目: hadoop   文件: JobClient.java
/**
 * Gets all the jobs which were added to particular Job Queue
 * 
 * @param queueName name of the Job Queue
 * @return Array of jobs present in the job queue
 * @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;
  } catch (InterruptedException ie) {
    throw new IOException(ie);
  }
}
 
源代码2 项目: hadoop   文件: JobClient.java
/**
 * Gets the queue information associated to a particular Job Queue
 * 
 * @param queueName name of the job queue.
 * @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);
      }
    });
    if (queueInfo != null) {
      return new JobQueueInfo(queueInfo);
    }
    return null;
  } catch (InterruptedException ie) {
    throw new IOException(ie);
  }
}
 
源代码3 项目: big-c   文件: JobClient.java
/**
 * Gets all the jobs which were added to particular Job Queue
 * 
 * @param queueName name of the Job Queue
 * @return Array of jobs present in the job queue
 * @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;
  } catch (InterruptedException ie) {
    throw new IOException(ie);
  }
}
 
源代码4 项目: big-c   文件: JobClient.java
/**
 * Gets the queue information associated to a particular Job Queue
 * 
 * @param queueName name of the job queue.
 * @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);
      }
    });
    if (queueInfo != null) {
      return new JobQueueInfo(queueInfo);
    }
    return null;
  } catch (InterruptedException ie) {
    throw new IOException(ie);
  }
}
 
源代码5 项目: hadoop   文件: ResourceMgrDelegate.java
public QueueInfo getQueue(String queueName) throws IOException,
InterruptedException {
  try {
    org.apache.hadoop.yarn.api.records.QueueInfo queueInfo =
        client.getQueueInfo(queueName);
    return (queueInfo == null) ? null : TypeConverter.fromYarn(queueInfo,
        conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码6 项目: hadoop   文件: ResourceMgrDelegate.java
public QueueInfo[] getQueues() throws IOException, InterruptedException {
  try {
    return TypeConverter.fromYarnQueueInfo(client.getAllQueues(), this.conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码7 项目: hadoop   文件: ResourceMgrDelegate.java
public QueueInfo[] getRootQueues() throws IOException, InterruptedException {
  try {
    return TypeConverter.fromYarnQueueInfo(client.getRootQueueInfos(),
        this.conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码8 项目: hadoop   文件: ResourceMgrDelegate.java
public QueueInfo[] getChildQueues(String parent) throws IOException,
    InterruptedException {
  try {
    return TypeConverter.fromYarnQueueInfo(client.getChildQueueInfos(parent),
      this.conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码9 项目: hadoop   文件: JobClient.java
private JobQueueInfo getJobQueueInfo(QueueInfo queue) {
  JobQueueInfo ret = new JobQueueInfo(queue);
  // make sure to convert any children
  if (queue.getQueueChildren().size() > 0) {
    List<JobQueueInfo> childQueues = new ArrayList<JobQueueInfo>(queue
        .getQueueChildren().size());
    for (QueueInfo child : queue.getQueueChildren()) {
      childQueues.add(getJobQueueInfo(child));
    }
    ret.setChildren(childQueues);
  }
  return ret;
}
 
源代码10 项目: hadoop   文件: JobClient.java
private JobQueueInfo[] getJobQueueInfoArray(QueueInfo[] queues)
    throws IOException {
  JobQueueInfo[] ret = new JobQueueInfo[queues.length];
  for (int i = 0; i < queues.length; i++) {
    ret[i] = getJobQueueInfo(queues[i]);
  }
  return ret;
}
 
源代码11 项目: hadoop   文件: JobQueueInfo.java
JobQueueInfo(QueueInfo queue) {
  this(queue.getQueueName(), queue.getSchedulingInfo());
  setQueueState(queue.getState().getStateName());
  setQueueChildren(queue.getQueueChildren());
  setProperties(queue.getProperties());
  setJobStatuses(queue.getJobStatuses());
}
 
源代码12 项目: hadoop   文件: JobQueueInfo.java
@InterfaceAudience.Private
public void setChildren(List<JobQueueInfo> children) {
  List<QueueInfo> list = new ArrayList<QueueInfo>();
  for (JobQueueInfo q : children) {
    list.add(q);
  }
  super.setQueueChildren(list);
}
 
源代码13 项目: hadoop   文件: JobQueueInfo.java
public List<JobQueueInfo> getChildren() {
  List<JobQueueInfo> list = new ArrayList<JobQueueInfo>();
  for (QueueInfo q : super.getQueueChildren()) {
    list.add((JobQueueInfo)q);
  }
  return list;
}
 
源代码14 项目: big-c   文件: ResourceMgrDelegate.java
public QueueInfo getQueue(String queueName) throws IOException,
InterruptedException {
  try {
    org.apache.hadoop.yarn.api.records.QueueInfo queueInfo =
        client.getQueueInfo(queueName);
    return (queueInfo == null) ? null : TypeConverter.fromYarn(queueInfo,
        conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码15 项目: big-c   文件: ResourceMgrDelegate.java
public QueueInfo[] getQueues() throws IOException, InterruptedException {
  try {
    return TypeConverter.fromYarnQueueInfo(client.getAllQueues(), this.conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码16 项目: big-c   文件: ResourceMgrDelegate.java
public QueueInfo[] getRootQueues() throws IOException, InterruptedException {
  try {
    return TypeConverter.fromYarnQueueInfo(client.getRootQueueInfos(),
        this.conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码17 项目: big-c   文件: ResourceMgrDelegate.java
public QueueInfo[] getChildQueues(String parent) throws IOException,
    InterruptedException {
  try {
    return TypeConverter.fromYarnQueueInfo(client.getChildQueueInfos(parent),
      this.conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码18 项目: big-c   文件: JobClient.java
private JobQueueInfo getJobQueueInfo(QueueInfo queue) {
  JobQueueInfo ret = new JobQueueInfo(queue);
  // make sure to convert any children
  if (queue.getQueueChildren().size() > 0) {
    List<JobQueueInfo> childQueues = new ArrayList<JobQueueInfo>(queue
        .getQueueChildren().size());
    for (QueueInfo child : queue.getQueueChildren()) {
      childQueues.add(getJobQueueInfo(child));
    }
    ret.setChildren(childQueues);
  }
  return ret;
}
 
源代码19 项目: big-c   文件: JobClient.java
private JobQueueInfo[] getJobQueueInfoArray(QueueInfo[] queues)
    throws IOException {
  JobQueueInfo[] ret = new JobQueueInfo[queues.length];
  for (int i = 0; i < queues.length; i++) {
    ret[i] = getJobQueueInfo(queues[i]);
  }
  return ret;
}
 
源代码20 项目: big-c   文件: JobQueueInfo.java
JobQueueInfo(QueueInfo queue) {
  this(queue.getQueueName(), queue.getSchedulingInfo());
  setQueueState(queue.getState().getStateName());
  setQueueChildren(queue.getQueueChildren());
  setProperties(queue.getProperties());
  setJobStatuses(queue.getJobStatuses());
}
 
源代码21 项目: big-c   文件: JobQueueInfo.java
@InterfaceAudience.Private
public void setChildren(List<JobQueueInfo> children) {
  List<QueueInfo> list = new ArrayList<QueueInfo>();
  for (JobQueueInfo q : children) {
    list.add(q);
  }
  super.setQueueChildren(list);
}
 
源代码22 项目: big-c   文件: JobQueueInfo.java
public List<JobQueueInfo> getChildren() {
  List<JobQueueInfo> list = new ArrayList<JobQueueInfo>();
  for (QueueInfo q : super.getQueueChildren()) {
    list.add((JobQueueInfo)q);
  }
  return list;
}
 
源代码23 项目: incubator-tez   文件: ResourceMgrDelegate.java
public QueueInfo getQueue(String queueName) throws IOException,
InterruptedException {
  try {
    org.apache.hadoop.yarn.api.records.QueueInfo queueInfo =
        client.getQueueInfo(queueName);
    return (queueInfo == null) ? null : TypeConverter.fromYarn(queueInfo,
        conf);
    } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码24 项目: incubator-tez   文件: ResourceMgrDelegate.java
public QueueInfo[] getQueues() throws IOException, InterruptedException {
  try {
    return TypeConverter.fromYarnQueueInfo(client.getAllQueues(), this.conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码25 项目: incubator-tez   文件: ResourceMgrDelegate.java
public QueueInfo[] getRootQueues() throws IOException, InterruptedException {
  try {
    return TypeConverter.fromYarnQueueInfo(client.getRootQueueInfos(),
        this.conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码26 项目: incubator-tez   文件: ResourceMgrDelegate.java
public QueueInfo[] getChildQueues(String parent) throws IOException,
    InterruptedException {
  try {
    return TypeConverter.fromYarnQueueInfo(client.getChildQueueInfos(parent),
      this.conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码27 项目: tez   文件: ResourceMgrDelegate.java
public QueueInfo getQueue(String queueName) throws IOException,
InterruptedException {
  try {
    org.apache.hadoop.yarn.api.records.QueueInfo queueInfo =
        client.getQueueInfo(queueName);
    return (queueInfo == null) ? null : TypeConverter.fromYarn(queueInfo,
        conf);
    } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码28 项目: tez   文件: ResourceMgrDelegate.java
public QueueInfo[] getQueues() throws IOException, InterruptedException {
  try {
    return TypeConverter.fromYarnQueueInfo(client.getAllQueues(), this.conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码29 项目: tez   文件: ResourceMgrDelegate.java
public QueueInfo[] getRootQueues() throws IOException, InterruptedException {
  try {
    return TypeConverter.fromYarnQueueInfo(client.getRootQueueInfos(),
        this.conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
源代码30 项目: tez   文件: ResourceMgrDelegate.java
public QueueInfo[] getChildQueues(String parent) throws IOException,
    InterruptedException {
  try {
    return TypeConverter.fromYarnQueueInfo(client.getChildQueueInfos(parent),
      this.conf);
  } catch (YarnException e) {
    throw new IOException(e);
  }
}
 
 类方法
 同包方法