Example usage for org.apache.hadoop.mapred JobConf get

List of usage examples for org.apache.hadoop.mapred JobConf get

Introduction

In this page you can find the example usage for org.apache.hadoop.mapred JobConf get.

Prototype

public String get(String name) 

Source Link

Document

Get the value of the name property, null if no such property exists.

Usage

From source file:com.ibm.bi.dml.runtime.matrix.mapred.MRJobConfiguration.java

License:Open Source License

public static CSVReblockInstruction[] getCSVReblockInstructions(JobConf job)
        throws DMLUnsupportedOperationException, DMLRuntimeException {
    String str = job.get(CSV_REBLOCK_INSTRUCTIONS_CONFIG);
    CSVReblockInstruction[] reblock_instructions = MRInstructionParser.parseCSVReblockInstructions(str);
    return reblock_instructions;
}

From source file:com.ibm.bi.dml.runtime.matrix.mapred.MRJobConfiguration.java

License:Open Source License

public static CSVWriteInstruction[] getCSVWriteInstructions(JobConf job)
        throws DMLUnsupportedOperationException, DMLRuntimeException {
    String str = job.get(CSV_WRITE_INSTRUCTIONS_CONFIG);
    CSVWriteInstruction[] reblock_instructions = MRInstructionParser.parseCSVWriteInstructions(str);
    return reblock_instructions;
}

From source file:com.ibm.bi.dml.runtime.matrix.mapred.MRJobConfiguration.java

License:Open Source License

public static AggregateInstruction[] getAggregateInstructions(JobConf job)
        throws DMLUnsupportedOperationException, DMLRuntimeException {
    String str = job.get(AGGREGATE_INSTRUCTIONS_CONFIG);
    AggregateInstruction[] agg_instructions = MRInstructionParser.parseAggregateInstructions(str);
    return agg_instructions;
}

From source file:com.ibm.bi.dml.runtime.matrix.mapred.MRJobConfiguration.java

License:Open Source License

public static MRInstruction[] getCombineInstruction(JobConf job)
        throws DMLUnsupportedOperationException, DMLRuntimeException {
    String str = job.get(COMBINE_INSTRUCTIONS_CONFIG);
    MRInstruction[] comb_instructions = MRInstructionParser.parseCombineInstructions(str);
    return comb_instructions;
}

From source file:com.ibm.bi.dml.runtime.matrix.mapred.MRJobConfiguration.java

License:Open Source License

public static MRInstruction[] getInstructionsInMapper(JobConf job)
        throws DMLUnsupportedOperationException, DMLRuntimeException {
    String str = job.get(INSTRUCTIONS_IN_MAPPER_CONFIG);
    MRInstruction[] instructions = MRInstructionParser.parseMixedInstructions(str);
    return instructions;
}

From source file:com.ibm.bi.dml.runtime.matrix.mapred.MRJobConfiguration.java

License:Open Source License

public static String getProgramBlocks(JobConf job) {
    String str = job.get(PARFOR_PROGRAMBLOCKS_CONFIG);
    return str;
}

From source file:com.ibm.bi.dml.runtime.matrix.mapred.MRJobConfiguration.java

License:Open Source License

public static long getPartitioningNumRows(JobConf job) {
    return Long.parseLong(job.get(PARTITIONING_INPUT_MATRIX_NUM_ROW_CONFIG));
}

From source file:com.ibm.bi.dml.runtime.matrix.mapred.MRJobConfiguration.java

License:Open Source License

public static long getPartitioningNumCols(JobConf job) {
    return Long.parseLong(job.get(PARTITIONING_INPUT_MATRIX_NUM_COLUMN_CONFIG));
}

From source file:com.ibm.bi.dml.runtime.matrix.mapred.MRJobConfiguration.java

License:Open Source License

public static int getPartitioningBlockNumRows(JobConf job) {
    return Integer.parseInt(job.get(PARTITIONING_INPUT_BLOCK_NUM_ROW_CONFIG));
}

From source file:com.ibm.bi.dml.runtime.matrix.mapred.MRJobConfiguration.java

License:Open Source License

public static int getPartitioningBlockNumCols(JobConf job) {
    return Integer.parseInt(job.get(PARTITIONING_INPUT_BLOCK_NUM_COLUMN_CONFIG));
}