Package org.apache.hadoop.hive.ql.plan

Examples of org.apache.hadoop.hive.ql.plan.ScriptDesc


                           getStringColumn("tvalue")),
                           outputColumns, false,
        -1, 1, -1));

    Operator<scriptDesc> op0 = OperatorFactory.get
    (new scriptDesc("/bin/cat",
        PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "tkey,tvalue"),
        PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "key,value")),
     op1);

    Operator<selectDesc> op4 = OperatorFactory.get(new selectDesc(
View Full Code Here


                           getStringColumn("tvalue")),
                           outputColumns, false,
        -1, 1, -1));

    Operator<scriptDesc> op0 = OperatorFactory.get
      (new scriptDesc("\'/bin/cat\'",
          PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "tkey,tvalue"),
          PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "tkey,tvalue")),
       op1);

    Operator<selectDesc> op4 = OperatorFactory.get(new selectDesc(
View Full Code Here

      op.setConf(selectCtx);

      // scriptOperator to echo the output of the select
      tableDesc scriptOutput = PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "a,b");
      tableDesc scriptInput  = PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "a,b");
      scriptDesc sd = new scriptDesc("cat", scriptOutput, scriptInput);
      Operator<scriptDesc> sop = OperatorFactory.getAndMakeChild(sd, op);

      // Collect operator to observe the output of the script
      collectDesc cd = new collectDesc (Integer.valueOf(10));
      CollectOperator cdop = (CollectOperator) OperatorFactory.getAndMakeChild(cd, sop);
View Full Code Here

    else
      outInfo = getTableDescFromSerDe((ASTNode)(((ASTNode)trfm.getChild(outputSerDeChildNum))).getChild(0), columns.toString(), defaultOutputColList);

    Operator output = putOpInsertMap(OperatorFactory
            .getAndMakeChild(
                new scriptDesc(
                               getFixedCmd(stripQuotes(trfm.getChild(execPos).getText())),
                      outInfo, inInfo),
                new RowSchema(out_rwsch.getColumnInfos()), input), out_rwsch);

    return output;
View Full Code Here

TOP

Related Classes of org.apache.hadoop.hive.ql.plan.ScriptDesc

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.