Package org.apache.hadoop.hive.ql.exec

Examples of org.apache.hadoop.hive.ql.exec.AppMasterEventOperator


      Object... nodeOutputs)
      throws SemanticException {

    OptimizeTezProcContext context = (OptimizeTezProcContext) procContext;

    AppMasterEventOperator event = (AppMasterEventOperator) nd;
    AppMasterEventDesc desc = event.getConf();

    if (desc.getStatistics().getDataSize() > context.conf
        .getLongVar(ConfVars.TEZ_DYNAMIC_PARTITION_PRUNING_MAX_DATA_SIZE)) {
      Operator<?> child = event;
      Operator<?> curr = event;
View Full Code Here


  @Override
  public Object process(Node nd, Stack<Node> stack, NodeProcessorCtx procCtx, Object... nodeOutputs)
      throws SemanticException {
    GenTezProcContext context = (GenTezProcContext) procCtx;
    AppMasterEventOperator event = (AppMasterEventOperator) nd;
    DynamicPruningEventDesc desc = (DynamicPruningEventDesc) event.getConf();

    // simply need to remember that we've seen an event operator.
    context.eventOperatorSet.add(event);

    // and remember link between event and table scan
View Full Code Here

      LOG.info("Cycle free: " + cycleFree);
    }
  }

  private void removeEventOperator(Set<Operator<?>> component) {
    AppMasterEventOperator victim = null;
    for (Operator<?> o : component) {
      if (o instanceof AppMasterEventOperator) {
        if (victim == null
            || o.getConf().getStatistics().getDataSize() < victim.getConf().getStatistics()
                .getDataSize()) {
          victim = (AppMasterEventOperator) o;
        }
      }
    }

    Operator<?> child = victim;
    Operator<?> curr = victim;

    while (curr.getChildOperators().size() <= 1) {
      child = curr;
      curr = curr.getParentOperators().get(0);
    }

    // at this point we've found the fork in the op pipeline that has the
    // pruning as a child plan.
    LOG.info("Disabling dynamic pruning for: "
        + ((DynamicPruningEventDesc) victim.getConf()).getTableScan().toString()
        + ". Needed to break cyclic dependency");
    curr.removeChild(child);
  }
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hive.ql.exec.AppMasterEventOperator

Copyright © 2018 www.massapicom. 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.