当前位置: 首页>>代码示例>>Java>>正文


Java Lock.NoLock方法代码示例

本文整理汇总了Java中org.apache.hadoop.yarn.server.utils.Lock.NoLock方法的典型用法代码示例。如果您正苦于以下问题:Java Lock.NoLock方法的具体用法?Java Lock.NoLock怎么用?Java Lock.NoLock使用的例子?那么恭喜您, 这里精选的方法代码示例或许可以为您提供帮助。您也可以进一步了解该方法所在org.apache.hadoop.yarn.server.utils.Lock的用法示例。


在下文中一共展示了Lock.NoLock方法的15个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于系统推荐出更棒的Java代码示例。

示例1: getQueueInfo

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Override
@Lock(Lock.NoLock.class)
public QueueInfo getQueueInfo(String queueName, 
    boolean includeChildQueues, boolean recursive) 
throws IOException {
  CSQueue queue = null;

  synchronized (this) {
    queue = this.queues.get(queueName); 
  }

  if (queue == null) {
    throw new IOException("Unknown queue: " + queueName);
  }
  return queue.getQueueInfo(includeChildQueues, recursive);
}
 
开发者ID:Nextzero,项目名称:hadoop-2.6.0-cdh5.4.3,代码行数:17,代码来源:CapacityScheduler.java

示例2: getQueueInfo

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Override
@Lock(Lock.NoLock.class)
public QueueInfo getQueueInfo(String queueName, 
    boolean includeChildQueues, boolean recursive) 
throws IOException {
  CSQueue queue = null;
  queue = this.queues.get(queueName);
  if (queue == null) {
    throw new IOException("Unknown queue: " + queueName);
  }
  return queue.getQueueInfo(includeChildQueues, recursive);
}
 
开发者ID:naver,项目名称:hadoop,代码行数:13,代码来源:CapacityScheduler.java

示例3: getQueueUserAclInfo

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Override
@Lock(Lock.NoLock.class)
public List<QueueUserACLInfo> getQueueUserAclInfo() {
  UserGroupInformation user = null;
  try {
    user = UserGroupInformation.getCurrentUser();
  } catch (IOException ioe) {
    // should never happen
    return new ArrayList<QueueUserACLInfo>();
  }

  return root.getQueueUserAclInfo(user);
}
 
开发者ID:naver,项目名称:hadoop,代码行数:14,代码来源:CapacityScheduler.java

示例4: getApplicationAttempt

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Lock(Lock.NoLock.class)
@VisibleForTesting
@Override
public FiCaSchedulerApp getApplicationAttempt(
    ApplicationAttemptId applicationAttemptId) {
  return super.getApplicationAttempt(applicationAttemptId);
}
 
开发者ID:naver,项目名称:hadoop,代码行数:8,代码来源:CapacityScheduler.java

示例5: getApplicationAttempt

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Lock(Lock.NoLock.class)
@VisibleForTesting
public FiCaSchedulerApp getApplicationAttempt(
    ApplicationAttemptId applicationAttemptId) {
  SchedulerApplication app =
      applications.get(applicationAttemptId.getApplicationId());
  if (app != null) {
    return (FiCaSchedulerApp) app.getCurrentAppAttempt();
  }
  return null;
}
 
开发者ID:Seagate,项目名称:hadoop-on-lustre2,代码行数:12,代码来源:CapacityScheduler.java

示例6: allocate

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Override
@Lock(Lock.NoLock.class)
public Allocation allocate(ApplicationAttemptId applicationAttemptId,
    List<ResourceRequest> ask, List<ContainerId> release, 
    List<String> blacklistAdditions, List<String> blacklistRemovals) {

  FiCaSchedulerApp application = getApplicationAttempt(applicationAttemptId);
  if (application == null) {
    LOG.info("Calling allocate on removed " +
        "or non existant application " + applicationAttemptId);
    return EMPTY_ALLOCATION;
  }
  
  // Sanity check
  SchedulerUtils.normalizeRequests(
      ask, getResourceCalculator(), getClusterResource(),
      getMinimumResourceCapability(), getMaximumResourceCapability());

  // Release containers
  releaseContainers(release, application);

  synchronized (application) {

    // make sure we aren't stopping/removing the application
    // when the allocate comes in
    if (application.isStopped()) {
      LOG.info("Calling allocate on a stopped " +
          "application " + applicationAttemptId);
      return EMPTY_ALLOCATION;
    }

    if (!ask.isEmpty()) {

      if(LOG.isDebugEnabled()) {
        LOG.debug("allocate: pre-update" +
          " applicationAttemptId=" + applicationAttemptId + 
          " application=" + application);
      }
      application.showRequests();

      // Update application requests
      application.updateResourceRequests(ask);

      LOG.debug("allocate: post-update");
      application.showRequests();
    }

    if(LOG.isDebugEnabled()) {
      LOG.debug("allocate:" +
        " applicationAttemptId=" + applicationAttemptId + 
        " #ask=" + ask.size());
    }

    application.updateBlacklist(blacklistAdditions, blacklistRemovals);

    return application.getAllocation(getResourceCalculator(),
                 clusterResource, getMinimumResourceCapability());
  }
}
 
开发者ID:naver,项目名称:hadoop,代码行数:60,代码来源:CapacityScheduler.java

示例7: getNode

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Lock(Lock.NoLock.class)
public FiCaSchedulerNode getNode(NodeId nodeId) {
  return nodes.get(nodeId);
}
 
开发者ID:naver,项目名称:hadoop,代码行数:5,代码来源:CapacityScheduler.java

示例8: getAllNodes

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Lock(Lock.NoLock.class)
Map<NodeId, FiCaSchedulerNode> getAllNodes() {
  return nodes;
}
 
开发者ID:naver,项目名称:hadoop,代码行数:5,代码来源:CapacityScheduler.java

示例9: recover

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Override
@Lock(Lock.NoLock.class)
public void recover(RMState state) throws Exception {
  // NOT IMPLEMENTED
}
 
开发者ID:naver,项目名称:hadoop,代码行数:6,代码来源:CapacityScheduler.java

示例10: allocate

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Override
@Lock(Lock.NoLock.class)
public Allocation allocate(ApplicationAttemptId applicationAttemptId,
    List<ResourceRequest> ask, List<ContainerId> release, 
    List<String> blacklistAdditions, List<String> blacklistRemovals) {

  FiCaSchedulerApp application = getApplicationAttempt(applicationAttemptId);
  if (application == null) {
    LOG.info("Calling allocate on removed " +
        "or non existant application " + applicationAttemptId);
    return EMPTY_ALLOCATION;
  }
  
  // Sanity check
  SchedulerUtils.normalizeRequests(
      ask, getResourceCalculator(), getClusterResource(),
      getMinimumResourceCapability(), getMaximumResourceCapability());

  // Release containers
 
  releaseContainers(release, application);

  synchronized (application) {

    // make sure we aren't stopping/removing the application
    // when the allocate comes in
    if (application.isStopped()) {
      LOG.info("Calling allocate on a stopped " +
          "application " + applicationAttemptId);
      return EMPTY_ALLOCATION;
    }

    if (!ask.isEmpty()) {

      if(LOG.isDebugEnabled()) {
        LOG.debug("allocate: pre-update" +
          " applicationAttemptId=" + applicationAttemptId + 
          " application=" + application);
      }
      application.showRequests();

      // Update application requests
      application.updateResourceRequests(ask);

      LOG.debug("allocate: post-update");
      application.showRequests();
    }

    if(LOG.isDebugEnabled()) {
      LOG.debug("allocate:" +
        " applicationAttemptId=" + applicationAttemptId + 
        " #ask=" + ask.size());
    }

    application.updateBlacklist(blacklistAdditions, blacklistRemovals);

    return application.getAllocation(getResourceCalculator(),
                 clusterResource, getMinimumResourceCapability());
  }
}
 
开发者ID:yncxcw,项目名称:big-c,代码行数:61,代码来源:CapacityScheduler.java

示例11: allocate

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Override
@Lock(Lock.NoLock.class)
public Allocation allocate(ApplicationAttemptId applicationAttemptId,
    List<ResourceRequest> ask, List<ContainerId> release, 
    List<String> blacklistAdditions, List<String> blacklistRemovals) {

  FiCaSchedulerApp application = getApplication(applicationAttemptId);
  if (application == null) {
    LOG.info("Calling allocate on removed " +
        "or non existant application " + applicationAttemptId);
    return EMPTY_ALLOCATION;
  }
  
  // Sanity check
  SchedulerUtils.normalizeRequests(
      ask, getResourceCalculator(), getClusterResources(),
      getMinimumResourceCapability(), maximumAllocation);

  // Release containers
  for (ContainerId releasedContainerId : release) {
    RMContainer rmContainer = getRMContainer(releasedContainerId);
    if (rmContainer == null) {
       RMAuditLogger.logFailure(application.getUser(),
           AuditConstants.RELEASE_CONTAINER, 
           "Unauthorized access or invalid container", "CapacityScheduler",
           "Trying to release container not owned by app or with invalid id",
           application.getApplicationId(), releasedContainerId);
    }
    completedContainer(rmContainer,
        SchedulerUtils.createAbnormalContainerStatus(
            releasedContainerId, 
            SchedulerUtils.RELEASED_CONTAINER),
        RMContainerEventType.RELEASED);
  }

  synchronized (application) {

    // make sure we aren't stopping/removing the application
    // when the allocate comes in
    if (application.isStopped()) {
      LOG.info("Calling allocate on a stopped " +
          "application " + applicationAttemptId);
      return EMPTY_ALLOCATION;
    }

    if (!ask.isEmpty()) {

      if(LOG.isDebugEnabled()) {
        LOG.debug("allocate: pre-update" +
          " applicationAttemptId=" + applicationAttemptId + 
          " application=" + application);
      }
      application.showRequests();

      // Update application requests
      application.updateResourceRequests(ask, 
          blacklistAdditions, blacklistRemovals);

      LOG.debug("allocate: post-update");
      application.showRequests();
    }

    if(LOG.isDebugEnabled()) {
      LOG.debug("allocate:" +
        " applicationAttemptId=" + applicationAttemptId + 
        " #ask=" + ask.size());
    }

    return application.getAllocation(getResourceCalculator(),
                 clusterResource, getMinimumResourceCapability());
  }
}
 
开发者ID:ict-carch,项目名称:hadoop-plus,代码行数:73,代码来源:CapacityScheduler.java

示例12: getApplication

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Lock(Lock.NoLock.class)
FiCaSchedulerApp getApplication(ApplicationAttemptId applicationAttemptId) {
  return applications.get(applicationAttemptId);
}
 
开发者ID:ict-carch,项目名称:hadoop-plus,代码行数:5,代码来源:CapacityScheduler.java

示例13: getNode

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Lock(Lock.NoLock.class)
FiCaSchedulerNode getNode(NodeId nodeId) {
  return nodes.get(nodeId);
}
 
开发者ID:ict-carch,项目名称:hadoop-plus,代码行数:5,代码来源:CapacityScheduler.java

示例14: allocate

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Override
@Lock(Lock.NoLock.class)
public Allocation allocate(ApplicationAttemptId applicationAttemptId,
    List<ResourceRequest> ask, List<ContainerId> release,
    List<String> blacklistAdditions, List<String> blacklistRemovals,
    List<UpdateContainerRequest> increaseRequests,
    List<UpdateContainerRequest> decreaseRequests) {

  FiCaSchedulerApp application = getApplicationAttempt(applicationAttemptId);
  if (application == null) {
    return EMPTY_ALLOCATION;
  }

  // Release containers
  releaseContainers(release, application);

  // update increase requests
  LeafQueue updateDemandForQueue =
      updateIncreaseRequests(increaseRequests, application);

  // Decrease containers
  decreaseContainers(decreaseRequests, application);

  // Sanity check for new allocation requests
  SchedulerUtils.normalizeRequests(
      ask, getResourceCalculator(), getClusterResource(),
      getMinimumResourceCapability(), getMaximumResourceCapability());

  Allocation allocation;

  synchronized (application) {

    // make sure we aren't stopping/removing the application
    // when the allocate comes in
    if (application.isStopped()) {
      return EMPTY_ALLOCATION;
    }

    // Process resource requests
    if (!ask.isEmpty()) {
      if(LOG.isDebugEnabled()) {
        LOG.debug("allocate: pre-update " + applicationAttemptId +
            " ask size =" + ask.size());
        application.showRequests();
      }

      // Update application requests
      if (application.updateResourceRequests(ask)
          && (updateDemandForQueue == null)) {
        updateDemandForQueue = (LeafQueue) application.getQueue();
      }

      if(LOG.isDebugEnabled()) {
        LOG.debug("allocate: post-update");
        application.showRequests();
      }
    }

    application.updateBlacklist(blacklistAdditions, blacklistRemovals);

    allocation = application.getAllocation(getResourceCalculator(),
                 clusterResource, getMinimumResourceCapability());
  }

  if (updateDemandForQueue != null && !application
      .isWaitingForAMContainer()) {
    updateDemandForQueue.getOrderingPolicy().demandUpdated(application);
  }

  return allocation;

}
 
开发者ID:hopshadoop,项目名称:hops,代码行数:73,代码来源:CapacityScheduler.java

示例15: getAllNodes

import org.apache.hadoop.yarn.server.utils.Lock; //导入方法依赖的package包/类
@Lock(Lock.NoLock.class)
public Map<NodeId, FiCaSchedulerNode> getAllNodes() {
  return nodes;
}
 
开发者ID:hopshadoop,项目名称:hops,代码行数:5,代码来源:CapacityScheduler.java


注:本文中的org.apache.hadoop.yarn.server.utils.Lock.NoLock方法示例由纯净天空整理自Github/MSDocs等开源代码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。