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

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


    Operator<fileSinkDesc> op3 = OperatorFactory.get(new fileSinkDesc
                                                     (tmpdir + "mapplan2.out",
                                                      Utilities.defaultTd, false));

    Operator<scriptDesc> op2 = OperatorFactory.get
      (new scriptDesc("/bin/cat",
          PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "key,value"),
                      TextRecordWriter.class,
          PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "key,value"),
          TextRecordReader.class),
       op3);
View Full Code Here


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

    Operator<scriptDesc> op0 = OperatorFactory.get
    (new scriptDesc("/bin/cat",
        PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "key,value"),
                    TextRecordWriter.class,
        PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "tkey,tvalue"),
        TextRecordReader.class),
     op1);
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"),
                      TextRecordWriter.class,
          PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "tkey,tvalue"),
          TextRecordReader.class),
       op1);
View Full Code Here

    Class <? extends RecordReader> outRecordReader = getRecordReader((ASTNode)trfm.getChild(outputRecordReaderNum));
    Class <? extends RecordWriter> inRecordWriter = getRecordWriter((ASTNode)trfm.getChild(inputRecordWriterNum));

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

    return output;
  }
View Full Code Here

    // Output record readers
    Class <? extends RecordReader> outRecordReader = getRecordReader((ASTNode)trfm.getChild(outputRecordReaderNum));
   
    Operator output = putOpInsertMap(OperatorFactory
            .getAndMakeChild(
                new scriptDesc(getFixedCmd(stripQuotes(trfm.getChild(execPos).getText())),
                    inInfo, outInfo, outRecordReader),
                new RowSchema(out_rwsch.getColumnInfos()), input), out_rwsch);

    return output;
  }
View Full Code Here

    Operator<fileSinkDesc> op3 = OperatorFactory.get(new fileSinkDesc
                                                     (tmpdir + "mapplan2.out",
                                                      Utilities.defaultTd, false));

    Operator<scriptDesc> op2 = OperatorFactory.get
      (new scriptDesc("/bin/cat",
          PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "key,value"),
          PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "key,value"),
          TextRecordReader.class),
       op3);
View Full Code Here

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

    Operator<scriptDesc> op0 = OperatorFactory.get
    (new scriptDesc("/bin/cat",
        PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "key,value"),
        PlanUtils.getDefaultTableDesc("" + Utilities.tabCode, "tkey,tvalue"),
        TextRecordReader.class),
     op1);
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"),
          TextRecordReader.class),
       op1);
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, TextRecordReader.class);
      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

    Operator<fileSinkDesc> op3 = OperatorFactory.get(new fileSinkDesc
                                                     (tmpdir + "mapplan2.out",
                                                      Utilities.defaultTd, false));

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

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.