• 设为首页
  • 点击收藏
  • 手机版
    手机扫一扫访问
    迪恩网络手机版
  • 关注官方公众号
    微信扫一扫关注
    迪恩网络公众号

Java PigStats类代码示例

原作者: [db:作者] 来自: [db:来源] 收藏 邀请

本文整理汇总了Java中org.apache.pig.tools.pigstats.PigStats的典型用法代码示例。如果您正苦于以下问题:Java PigStats类的具体用法?Java PigStats怎么用?Java PigStats使用的例子?那么恭喜您, 这里精选的类代码示例或许可以为您提供帮助。



PigStats类属于org.apache.pig.tools.pigstats包,在下文中一共展示了PigStats类的20个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于我们的系统推荐出更棒的Java代码示例。

示例1: runSingle

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
/**
 * Run a pipeline on Hadoop.  
 * If there are no stores in this pipeline then nothing will be run.  
 * @param prop Map of properties that Pig should set when running the script.
 * This is intended for use with scripting languages that do not support
 * the Properties object.
 * @return {@link PigStats}, null if there is no bound query to run.
 * @throws IOException
 */
public PigStats runSingle(Properties prop) throws IOException {
    if (queries.size() > 1) {
        throw new IOException(
                "This pipeline contains multiple queries. Use run() method instead");
    }
    if (queries.isEmpty()) {
        LOG.info("No bound query to run");
        return null;
    }
    if (prop != null) {
        scriptContext.getPigContext().getProperties().putAll(prop);
    }
    PigStats ret = exec(queries.get(0)); 
    setPigStats(ret);
    return ret;
}
 
开发者ID:sigmoidanalytics,项目名称:spork-streaming,代码行数:26,代码来源:BoundScript.java


示例2: testBytesWritten_JIRA_1027

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
@Test
public void testBytesWritten_JIRA_1027() {

    File outputFile = null;
    try {
        String fileName = this.getClass().getName() + "_" + "testBytesWritten_JIRA_1027";
        outputFile = File.createTempFile(fileName, ".out");
        String filePath = outputFile.getAbsolutePath();
        outputFile.delete();
        PigServer pig = new PigServer(ExecType.LOCAL);
        pig.registerQuery("A = load 'test/org/apache/pig/test/data/passwd';");
        ExecJob job = pig.store("A", filePath);
        PigStats stats = job.getStatistics();
        File dataFile = new File( outputFile.getAbsoluteFile() + File.separator + "part-00000" );
        assertEquals(dataFile.length(), stats.getBytesWritten());
    } catch (IOException e) {
        LOG.error("Error while generating file", e);
        fail("Encountered IOException");
    } finally {
        if (outputFile != null) {
            // Hadoop Local mode creates a directory
            // Hence we need to delete a directory recursively
            deleteDirectory(outputFile);
        }
    }
}
 
开发者ID:sigmoidanalytics,项目名称:spork,代码行数:27,代码来源:TestPigStats.java


示例3: testGroupAllWithParallel

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
/**
 * Test parallelism for group all
 * @throws Exception
 */
@Test
public void testGroupAllWithParallel() throws Exception {
    PigServer pigServer = new PigServer(cluster.getExecType(), cluster
            .getProperties());
    
    
    pigServer.registerQuery("A = LOAD '" + INPUT_FILE + "' as (x:chararray);");
    pigServer.registerQuery("B = group A all parallel 5;");
    {
        Iterator<Tuple> iter = pigServer.openIterator("B");
        List<Tuple> expectedRes = 
            Util.getTuplesFromConstantTupleStrings(
                    new String[] {
                            "('all',{('one'),('two'),('two')})"
                    });
        Util.checkQueryOutputsAfterSort(iter, expectedRes);
        
        JobGraph jGraph = PigStats.get().getJobGraph();
        checkGroupAllWithParallelGraphResult(jGraph);
    }
}
 
开发者ID:sigmoidanalytics,项目名称:spork,代码行数:26,代码来源:TestGroupConstParallel.java


示例4: runEmbeddedScript

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
private static int runEmbeddedScript(PigContext pigContext, String file, String engine)
throws IOException {
	log.info("Run embedded script: " + engine);
	pigContext.connect();
	ScriptEngine scriptEngine = ScriptEngine.getInstance(engine);
	Map<String, List<PigStats>> statsMap = scriptEngine.run(pigContext, file);
	PigStatsUtil.setStatsMap(statsMap);

	int failCount = 0;
	int totalCount = 0;
	for (List<PigStats> lst : statsMap.values()) {
		if (lst != null && !lst.isEmpty()) {
			for (PigStats stats : lst) {
				if (!stats.isSuccessful()) failCount++;
				totalCount++;
			}
		}
	}
	return (totalCount > 0 && failCount == totalCount) ? ReturnCode.FAILURE
			: (failCount > 0) ? ReturnCode.PARTIAL_FAILURE
					: ReturnCode.SUCCESS;
}
 
开发者ID:sigmoidanalytics,项目名称:spork-streaming,代码行数:23,代码来源:Main.java


示例5: getJobs

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
/**
 * Retrieves a list of Job objects from the PigStats object
 * @param stats
 * @return A list of ExecJob objects
 */
protected List<ExecJob> getJobs(PigStats stats) {
    LinkedList<ExecJob> jobs = new LinkedList<ExecJob>();
    JobGraph jGraph = stats.getJobGraph();
    Iterator<JobStats> iter = jGraph.iterator();
    while (iter.hasNext()) {
        JobStats js = iter.next();
        for (OutputStats output : js.getOutputs()) {
            if (js.isSuccessful()) {
                jobs.add(new HJob(HJob.JOB_STATUS.COMPLETED, pigContext, output
                        .getPOStore(), output.getAlias(), stats));
            } else {
                HJob hjob = new HJob(HJob.JOB_STATUS.FAILED, pigContext, output
                        .getPOStore(), output.getAlias(), stats);
                hjob.setException(js.getException());
                jobs.add(hjob);
            }
        }
    }
    return jobs;
}
 
开发者ID:sigmoidanalytics,项目名称:spork-streaming,代码行数:26,代码来源:PigServer.java


示例6: storeEx

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
private PigStats storeEx(String alias, String filename, String func)
throws IOException {
    if ("@".equals(alias)) {
        alias = getLastRel();
    }
    currDAG.parseQuery();
    currDAG.buildPlan( alias );

    try {
        QueryParserUtils.attachStorePlan(scope, currDAG.lp, filename, func, currDAG.getOperator( alias ), alias, pigContext);
        currDAG.compile();
        return executeCompiledLogicalPlan();
    } catch (PigException e) {
        int errCode = 1002;
        String msg = "Unable to store alias " + alias;
        throw new PigException(msg, errCode, PigException.INPUT, e);
    }
}
 
开发者ID:sigmoidanalytics,项目名称:spork-streaming,代码行数:19,代码来源:PigServer.java


示例7: runJob

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
public void runJob() throws JobCreationException {
    RunJarSecurityManager secMan = new RunJarSecurityManager();
    try {
        RunJar.main(getNativeMRParams());
        MRPigStatsUtil.addNativeJobStats(PigStats.get(), this, true);
    } catch (SecurityException se) {
        if(secMan.getExitInvoked()) {
            if(secMan.getExitCode() != 0) {
                throw new JobCreationException("Native job returned with non-zero return code");
            }
            else {
                MRPigStatsUtil.addNativeJobStats(PigStats.get(), this, true);
            }
        }
    } catch (Throwable t) {
        JobCreationException e = new JobCreationException(
                "Cannot run native mapreduce job "+ t.getMessage(), t);
        MRPigStatsUtil.addNativeJobStats(PigStats.get(), this, false, e);
        throw e;
    } finally {
        secMan.retire();
    }
}
 
开发者ID:sigmoidanalytics,项目名称:spork,代码行数:24,代码来源:NativeMapReduceOper.java


示例8: testEmptyFile

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
@Test // PIG-2006
public void testEmptyFile() throws IOException {
    File f1 = new File(PIG_FILE);

    FileWriter fw1 = new FileWriter(f1);
    fw1.close();

    try {
       String[] args = { "-x", "local", "-c", PIG_FILE };
       PigStats stats = PigRunner.run(args, null);

       assertTrue(stats.isSuccessful());
       assertEquals( 0, stats.getReturnCode() );
    } finally {
        new File(PIG_FILE).delete();
        Util.deleteFile(cluster, OUTPUT_FILE);
    }
}
 
开发者ID:sigmoidanalytics,项目名称:spork,代码行数:19,代码来源:TestPigRunner.java


示例9: returnCodeTest2

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
@Test
public void returnCodeTest2() throws Exception {
    PrintWriter w = new PrintWriter(new FileWriter(PIG_FILE));
    w.println("A = load 'non-existine.file' as (a0, a1);");
    w.println("B = load 'data' as (b0, b1);");
    w.println("C = join B by b0, A by a0 using 'repl';");
    w.println("store C into '" + OUTPUT_FILE + "';");
    w.close();

    try {
        String[] args = { "-x", execType, PIG_FILE };
        PigStats stats = PigRunner.run(args, null);

        assertTrue(!stats.isSuccessful());
        assertTrue(stats.getReturnCode() != 0);
        assertTrue(stats.getOutputStats().size() == 0);

    } finally {
        new File(PIG_FILE).delete();
        Util.deleteFile(cluster, OUTPUT_FILE);
    }
}
 
开发者ID:sigmoidanalytics,项目名称:spork,代码行数:23,代码来源:TestPigRunner.java


示例10: testNagative7

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
@Test // test error message with file name
public void testNagative7() throws IOException {
    File f1 = new File("myscript.pig");
    f1.deleteOnExit();
    
    FileWriter fw1 = new FileWriter(f1);
    fw1.append("A = loadd '1.txt';");
    fw1.close();
    
    String[] args = { "-x", "local", "-c", "myscript.pig" };
    PigStats stats = PigRunner.run(args, null);
   
    Assert.assertFalse(stats.isSuccessful());
    
    String expected = "<file myscript.pig, line 1, column 0>";
    String msg = stats.getErrorMessage();
    
    Assert.assertFalse(msg == null);
    Assert.assertTrue(msg.startsWith(expected));
}
 
开发者ID:sigmoidanalytics,项目名称:spork-streaming,代码行数:21,代码来源:TestQueryParser.java


示例11: launchPig

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
/**
 * Runs the fetch task by executing chain of calls on the PhysicalPlan from the leaf
 * up to the LoadFunc
 *
 * @param pp - Physical plan
 * @return SimpleFetchPigStats instance representing the fetched result
 * @throws IOException
 */
public PigStats launchPig(PhysicalPlan pp) throws IOException {
    try {
        POStore poStore = (POStore) pp.getLeaves().get(0);
        init(pp, poStore);

        // run fetch
        runPipeline(poStore);

        UDFFinishVisitor udfFinisher = new UDFFinishVisitor(pp,
                new DependencyOrderWalker<PhysicalOperator, PhysicalPlan>(pp));
        udfFinisher.visit();

        return PigStats.start(new EmptyPigStats(pigContext, poStore));
    }
    finally {
        UDFContext.getUDFContext().addJobConf(null);
        pigContext.getProperties().remove(PigImplConstants.CONVERTED_TO_FETCH);
    }
}
 
开发者ID:sigmoidanalytics,项目名称:spork,代码行数:28,代码来源:FetchLauncher.java


示例12: simpleNegativeTest

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
@Test
    public void simpleNegativeTest() throws Exception {
        PrintWriter w = new PrintWriter(new FileWriter(PIG_FILE));
        w.println("A = load '" + INPUT_FILE + "' as (a0:int, a1:int, a2:int);");
        w.println("B = group A by a;");
        w.println("C = foreach B generate group, COUNT(A);");
        w.println("store C into '" + OUTPUT_FILE + "';");
        w.close();
        String[] args = { "-c", PIG_FILE };
        PigStats stats = PigRunner.run(args, null);
        assertTrue(stats.getReturnCode() == ReturnCode.PIG_EXCEPTION);
        // TODO: error message has changed. Need to catch the new message generated from the
        // new parser.
//        assertTrue(stats.getErrorCode() == 1000);
//        assertEquals("Error during parsing. Invalid alias: a in {a0: int,a1: int,a2: int}", 
//                stats.getErrorMessage());
    }
 
开发者ID:sigmoidanalytics,项目名称:spork-streaming,代码行数:18,代码来源:TestPigRunner.java


示例13: testRegisterExternalJar

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
@Test
public void testRegisterExternalJar() throws Exception {
    String[] args = { "-Dpig.additional.jars=pig-withouthadoop.jar",
            "-Dmapred.job.queue.name=default",
            "-e", "A = load '" + INPUT_FILE + "';store A into '" + OUTPUT_FILE + "';\n" };
    PigStats stats = PigRunner.run(args, new TestNotificationListener());        

    Util.deleteFile(cluster, OUTPUT_FILE);
    
    java.lang.reflect.Method getPigContext = stats.getClass()
            .getDeclaredMethod("getPigContext");

    getPigContext.setAccessible(true);

    PigContext ctx = (PigContext) getPigContext.invoke(stats);

    Assert.assertNotNull(ctx);

    assertTrue(ctx.extraJars.contains(ClassLoader.getSystemResource("pig-withouthadoop.jar")));
    assertTrue("default", ctx.getProperties().getProperty("mapred.job.queue.name")!=null && ctx.getProperties().getProperty("mapred.job.queue.name").equals("default")||
            ctx.getProperties().getProperty("mapreduce.job.queuename")!=null && ctx.getProperties().getProperty("mapreduce.job.queuename").equals("default"));
   
}
 
开发者ID:sigmoidanalytics,项目名称:spork-streaming,代码行数:24,代码来源:TestPigRunner.java


示例14: classLoaderTest

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
@Test
public void classLoaderTest() throws Exception {
    // Skip in hadoop 23 test, see PIG-2449
    if (Util.isHadoop23() || Util.isHadoop2_0())
        return;
    PrintWriter w = new PrintWriter(new FileWriter(PIG_FILE));
    w.println("register test/org/apache/pig/test/data/pigtestloader.jar");
    w.println("A = load '" + INPUT_FILE + "' using org.apache.pig.test.PigTestLoader();");
    w.println("store A into '" + OUTPUT_FILE + "';");
    w.close();
    
    try {
        String[] args = { PIG_FILE };
        PigStats stats = PigRunner.run(args, new TestNotificationListener());     
        assertTrue(stats.isSuccessful());          
    } finally {
        new File(PIG_FILE).delete();
        Util.deleteFile(cluster, OUTPUT_FILE);
    }
}
 
开发者ID:sigmoidanalytics,项目名称:spork-streaming,代码行数:21,代码来源:TestPigRunner.java


示例15: fsCommandTest

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
@Test
public void fsCommandTest() throws Exception {
    PrintWriter w = new PrintWriter(new FileWriter(PIG_FILE));
    w.println("fs -mv nonexist.file dummy.file");
    w.close();
    
    try {
        String[] args = { PIG_FILE };
        PigStats stats = PigRunner.run(args, new TestNotificationListener());
 
        assertTrue(!stats.isSuccessful());
        assertTrue(stats.getReturnCode() == PigRunner.ReturnCode.IO_EXCEPTION);
    } finally {
        new File(PIG_FILE).delete();
    }
}
 
开发者ID:sigmoidanalytics,项目名称:spork-streaming,代码行数:17,代码来源:TestPigRunner.java


示例16: execute

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
/**
 * Compile and execute the current plan.
 * @return
 * @throws IOException
 */
private PigStats execute() throws IOException {
    pigContext.getProperties().setProperty( PigContext.JOB_NAME, jobName );
    if( jobPriority != null ) {
        pigContext.getProperties().setProperty( PigContext.JOB_PRIORITY, jobPriority );
    }

    // In this plan, all stores in the plan will be executed. They should be ignored if the plan is reused.
    currDAG.countExecutedStores();

    currDAG.compile();

    if( currDAG.lp.size() == 0 ) {
       return PigStats.get();
    }

    pigContext.getProperties().setProperty("pig.logical.plan.signature", currDAG.lp.getSignature());

    PigStats stats = executeCompiledLogicalPlan();

    return stats;
}
 
开发者ID:sigmoidanalytics,项目名称:spork,代码行数:27,代码来源:PigServer.java


示例17: returnCodeTest

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
@Test
public void returnCodeTest() throws Exception {
    PrintWriter w = new PrintWriter(new FileWriter(PIG_FILE));
    w.println("A = load 'non-existine.file' as (a0:int, a1:int, a2:int);");
    w.println("B = filter A by a0 > 0;;");
    w.println("C = group B by $0;");
    w.println("D = join C by $0, B by $0;");
    w.println("store D into '" + OUTPUT_FILE + "';");
    w.close();
    
    try {
        String[] args = { PIG_FILE };
        PigStats stats = PigRunner.run(args, null);
        
        assertTrue(!stats.isSuccessful());
        assertTrue(stats.getReturnCode() != 0);
        assertTrue(stats.getOutputStats().size() == 0);
        
    } finally {
        new File(PIG_FILE).delete();
        Util.deleteFile(cluster, OUTPUT_FILE);
    }
}
 
开发者ID:sigmoidanalytics,项目名称:spork-streaming,代码行数:24,代码来源:TestPigRunner.java


示例18: returnCodeTest2

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
@Test
public void returnCodeTest2() throws Exception {
    PrintWriter w = new PrintWriter(new FileWriter(PIG_FILE));
    w.println("A = load 'non-existine.file' as (a0, a1);");
    w.println("B = load 'data' as (b0, b1);");
    w.println("C = join B by b0, A by a0 using 'repl';");
    w.println("store C into '" + OUTPUT_FILE + "';");
    w.close();
    
    try {
        String[] args = { PIG_FILE };
        PigStats stats = PigRunner.run(args, null);
        
        assertTrue(!stats.isSuccessful());
        assertTrue(stats.getReturnCode() != 0);
        assertTrue(stats.getOutputStats().size() == 0);
        
    } finally {
        new File(PIG_FILE).delete();
        Util.deleteFile(cluster, OUTPUT_FILE);
    }
}
 
开发者ID:sigmoidanalytics,项目名称:spork-streaming,代码行数:23,代码来源:TestPigRunner.java


示例19: testRightOuterJoin

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
@Test
public void testRightOuterJoin() throws Exception {
    PrintWriter w = new PrintWriter(new FileWriter(PIG_FILE));
    w.println("A = load '" + INPUT_FILE + "';");
    w.println("B = load '" + EMPTY_DIR + "' as (x:int);");
    w.println("C = join B by $0 right outer, A by $0;");
    w.println("store C into '" + OUTPUT_FILE + "';");
    w.close();
    
    try {
        String[] args = { PIG_FILE };
        PigStats stats = PigRunner.run(args, null);
 
        assertTrue(stats.isSuccessful());               
        assertEquals(2, stats.getNumberRecords(OUTPUT_FILE));                  
    } finally {
        new File(PIG_FILE).delete();
        Util.deleteFile(cluster, OUTPUT_FILE);
    }
}
 
开发者ID:sigmoidanalytics,项目名称:spork,代码行数:21,代码来源:TestEmptyInputDir.java


示例20: parameterSubstitutionTest

import org.apache.pig.tools.pigstats.PigStats; //导入依赖的package包/类
@Test
public void parameterSubstitutionTest() throws Exception {
    String macro = "define group_and_count (A,C) returns B, D {\n" +
        "    $B = JOIN $A BY user, $C BY user using 'replicated' partition by org.apache.pig.test.utils.SimpleCustomPartitioner parallel 5;\n" +
        "    $D = JOIN $A BY $0, $C BY $1 using 'skewed' parallel 5;\n" +
        "};\n";
    
    String script = 
        "alpha = load 'users' as (user, age, zip);\n" +
        "beta = load 'links' as (user, link, view);\n" +
        "gamma, sigma = group_and_count (alpha,beta);\n" +
        "store gamma into '$output1';\n" +
        "store sigma into '$output2';\n";
    
    File f1 = new File("myscript.pig");
    f1.deleteOnExit();
    
    FileWriter fw1 = new FileWriter(f1);
    fw1.append(macro).append(script);
    fw1.close();
    
    String[] args = { "-x", "local", "-p", "output1=byuser", "-p", "output2=byage", "-c", "myscript.pig" };
    PigStats stats = PigRunner.run(args, null);
 
    assertTrue(stats.isSuccessful());
}
 
开发者ID:sigmoidanalytics,项目名称:spork-streaming,代码行数:27,代码来源:TestMacroExpansion.java



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


鲜花

握手

雷人

路过

鸡蛋
该文章已有0人参与评论

请发表评论

全部评论

专题导读
上一篇:
Java CriteriaSet类代码示例发布时间:2022-05-22
下一篇:
Java Page类代码示例发布时间:2022-05-22
热门推荐
阅读排行榜

扫描微信二维码

查看手机版网站

随时了解更新最新资讯

139-2527-9053

在线客服(服务时间 9:00~18:00)

在线QQ客服
地址:深圳市南山区西丽大学城创智工业园
电邮:jeky_zhao#qq.com
移动电话:139-2527-9053

Powered by 互联科技 X3.4© 2001-2213 极客世界.|Sitemap