当前位置: 首页>>代码示例>>Java>>正文


Java TezCounter类代码示例

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


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

示例1: ShuffledUnorderedKVReader

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
public ShuffledUnorderedKVReader(ShuffleManager shuffleManager, Configuration conf,
    CompressionCodec codec, boolean ifileReadAhead, int ifileReadAheadLength, int ifileBufferSize,
    TezCounter inputRecordCounter)
    throws IOException {
  this.shuffleManager = shuffleManager;

  this.codec = codec;
  this.ifileReadAhead = ifileReadAhead;
  this.ifileReadAheadLength = ifileReadAheadLength;
  this.ifileBufferSize = ifileBufferSize;
  this.inputRecordCounter = inputRecordCounter;

  this.keyClass = ConfigUtils.getIntermediateInputKeyClass(conf);
  this.valClass = ConfigUtils.getIntermediateInputValueClass(conf);

  this.keyIn = new DataInputBuffer();
  this.valIn = new DataInputBuffer();

  SerializationFactory serializationFactory = new SerializationFactory(conf);

  this.keyDeserializer = serializationFactory.getDeserializer(keyClass);
  this.keyDeserializer.open(keyIn);
  this.valDeserializer = serializationFactory.getDeserializer(valClass);
  this.valDeserializer.open(valIn);
}
 
开发者ID:apache,项目名称:incubator-tez,代码行数:26,代码来源:ShuffledUnorderedKVReader.java

示例2: merge

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
public static
TezRawKeyValueIterator merge(Configuration conf, FileSystem fs,
                          Class keyClass, Class valueClass, 
                          CompressionCodec codec, boolean ifileReadAhead,
                          int ifileReadAheadLength, int ifileBufferSize,
                          Path[] inputs, boolean deleteInputs, 
                          int mergeFactor, Path tmpDir,
                          RawComparator comparator, Progressable reporter,
                          TezCounter readsCounter,
                          TezCounter writesCounter,
                          TezCounter bytesReadCounter,
                          Progress mergePhase)
throws IOException {
  return 
    new MergeQueue(conf, fs, inputs, deleteInputs, codec, ifileReadAhead,
                         ifileReadAheadLength, ifileBufferSize, false, comparator, 
                         reporter, null).merge(keyClass, valueClass,
                                         mergeFactor, tmpDir,
                                         readsCounter, writesCounter,
                                         bytesReadCounter,
                                         mergePhase);
}
 
开发者ID:apache,项目名称:incubator-tez,代码行数:23,代码来源:TezMerger.java

示例3: Segment

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
public Segment(Configuration conf, FileSystem fs, Path file,
    long segmentOffset, long segmentLength, CompressionCodec codec,
    boolean ifileReadAhead, int ifileReadAheadLength, int bufferSize,
    boolean preserve, TezCounter mergedMapOutputsCounter)
throws IOException {
  this.conf = conf;
  this.fs = fs;
  this.file = file;
  this.codec = codec;
  this.preserve = preserve;
  this.ifileReadAhead = ifileReadAhead;
  this.ifileReadAheadLength =ifileReadAheadLength;
  this.bufferSize = bufferSize;

  this.segmentOffset = segmentOffset;
  this.segmentLength = segmentLength;
  
  this.mapOutputsCounter = mergedMapOutputsCounter;
}
 
开发者ID:apache,项目名称:incubator-tez,代码行数:20,代码来源:TezMerger.java

示例4: ValuesIterator

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
public ValuesIterator (TezRawKeyValueIterator in, 
                       RawComparator<KEY> comparator, 
                       Class<KEY> keyClass,
                       Class<VALUE> valClass, Configuration conf,
                       TezCounter inputKeyCounter,
                       TezCounter inputValueCounter)
  throws IOException {
  this.in = in;
  this.comparator = comparator;
  this.inputKeyCounter = inputKeyCounter;
  this.inputValueCounter = inputValueCounter;
  SerializationFactory serializationFactory = new SerializationFactory(conf);
  this.keyDeserializer = serializationFactory.getDeserializer(keyClass);
  this.keyDeserializer.open(keyIn);
  this.valDeserializer = serializationFactory.getDeserializer(valClass);
  this.valDeserializer.open(this.valueIn);
}
 
开发者ID:apache,项目名称:incubator-tez,代码行数:18,代码来源:ValuesIterator.java

示例5: getLocalityInfo

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
public final TezCounter getLocalityInfo() {
  Map<String, TezCounter> dataLocalTask = getCounter(DAGCounter.class.getName(),
      DAGCounter.DATA_LOCAL_TASKS.toString());
  Map<String, TezCounter> rackLocalTask = getCounter(DAGCounter.class.getName(),
      DAGCounter.RACK_LOCAL_TASKS.toString());
  Map<String, TezCounter> otherLocalTask = getCounter(DAGCounter.class.getName(),
      DAGCounter.OTHER_LOCAL_TASKS.toString());

  if (!dataLocalTask.isEmpty()) {
    return dataLocalTask.get(DAGCounter.class.getName());
  }

  if (!rackLocalTask.isEmpty()) {
    return rackLocalTask.get(DAGCounter.class.getName());
  }

  if (!otherLocalTask.isEmpty()) {
    return otherLocalTask.get(DAGCounter.class.getName());
  }
  return null;
}
 
开发者ID:apache,项目名称:tez,代码行数:22,代码来源:TaskAttemptInfo.java

示例6: fromTez

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
public static Counters fromTez(TezCounters tezCounters) {
  if (tezCounters == null) {
    return null;
  }
  Counters counters = new Counters();
  for (CounterGroup xGrp : tezCounters) {
    counters.addGroup(xGrp.getName(), xGrp.getDisplayName());
    for (TezCounter xCounter : xGrp) {
      Counter counter =
          counters.findCounter(xGrp.getName(), xCounter.getName());
      counter.setValue(xCounter.getValue());

    }
  }
  return counters;
}
 
开发者ID:apache,项目名称:incubator-tez,代码行数:17,代码来源:TezTypeConverters.java

示例7: MRReaderMapReduce

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
public MRReaderMapReduce(JobConf jobConf, InputSplit inputSplit, TezCounters tezCounters,
    TezCounter inputRecordCounter, long clusterId, int vertexIndex, int appId, int taskIndex,
    int taskAttemptNumber) throws IOException {
  this.inputRecordCounter = inputRecordCounter;
  this.taskAttemptContext = new TaskAttemptContextImpl(jobConf, tezCounters, clusterId,
      vertexIndex, appId, taskIndex, taskAttemptNumber, true, null);

  Class<? extends org.apache.hadoop.mapreduce.InputFormat<?, ?>> inputFormatClazz;
  try {
    inputFormatClazz = taskAttemptContext.getInputFormatClass();
  } catch (ClassNotFoundException e) {
    throw new IOException("Unable to instantiate InputFormat class", e);
  }
  inputFormat = ReflectionUtils.newInstance(inputFormatClazz, jobConf);

  if (inputSplit != null) {
    this.inputSplit = inputSplit;
    setupNewRecordReader();
  }
}
 
开发者ID:apache,项目名称:incubator-tez,代码行数:21,代码来源:MRReaderMapReduce.java

示例8: convertCountersToATSMap

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
public static Map<String,Object> convertCountersToATSMap(TezCounters counters) {
  Map<String,Object> object = new LinkedHashMap<String, Object>();
  if (counters == null) {
      return object;
    }
  ArrayList<Object> counterGroupsList = new ArrayList<Object>();
  for (CounterGroup group : counters) {
      Map<String,Object> counterGroupMap = new LinkedHashMap<String, Object>();
      counterGroupMap.put(ATSConstants.COUNTER_GROUP_NAME, group.getName());
      counterGroupMap.put(ATSConstants.COUNTER_GROUP_DISPLAY_NAME,
              group.getDisplayName());
      ArrayList<Object> counterList = new ArrayList<Object>();
      for (TezCounter counter : group) {
          Map<String,Object> counterMap = new LinkedHashMap<String, Object>();
          counterMap.put(ATSConstants.COUNTER_NAME, counter.getName());
          counterMap.put(ATSConstants.COUNTER_DISPLAY_NAME,
                  counter.getDisplayName());
          counterMap.put(ATSConstants.COUNTER_VALUE, counter.getValue());
          counterList.add(counterMap);
        }
      putInto(counterGroupMap, ATSConstants.COUNTERS, counterList);
      counterGroupsList.add(counterGroupMap);
    }
  putInto(object, ATSConstants.COUNTER_GROUPS, counterGroupsList);
  return object;
}
 
开发者ID:apache,项目名称:incubator-tez,代码行数:27,代码来源:DAGUtils.java

示例9: UnorderedKVReader

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
public UnorderedKVReader(ShuffleManager shuffleManager, Configuration conf,
    CompressionCodec codec, boolean ifileReadAhead, int ifileReadAheadLength, int ifileBufferSize,
    TezCounter inputRecordCounter, InputContext context)
    throws IOException {
  this.shuffleManager = shuffleManager;
  this.context = context;
  this.codec = codec;
  this.ifileReadAhead = ifileReadAhead;
  this.ifileReadAheadLength = ifileReadAheadLength;
  this.ifileBufferSize = ifileBufferSize;
  this.inputRecordCounter = inputRecordCounter;

  this.keyClass = ConfigUtils.getIntermediateInputKeyClass(conf);
  this.valClass = ConfigUtils.getIntermediateInputValueClass(conf);

  this.keyIn = new DataInputBuffer();
  this.valIn = new DataInputBuffer();

  SerializationFactory serializationFactory = new SerializationFactory(conf);

  this.keyDeserializer = serializationFactory.getDeserializer(keyClass);
  this.keyDeserializer.open(keyIn);
  this.valDeserializer = serializationFactory.getDeserializer(valClass);
  this.valDeserializer.open(valIn);
}
 
开发者ID:apache,项目名称:tez,代码行数:26,代码来源:UnorderedKVReader.java

示例10: merge

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
public static
TezRawKeyValueIterator merge(Configuration conf, FileSystem fs,
                          Class keyClass, Class valueClass, 
                          CompressionCodec codec, boolean ifileReadAhead,
                          int ifileReadAheadLength, int ifileBufferSize,
                          Path[] inputs, boolean deleteInputs, 
                          int mergeFactor, Path tmpDir,
                          RawComparator comparator, Progressable reporter,
                          TezCounter readsCounter,
                          TezCounter writesCounter,
                          TezCounter bytesReadCounter,
                          Progress mergePhase)
    throws IOException, InterruptedException {
  return 
    new MergeQueue(conf, fs, inputs, deleteInputs, codec, ifileReadAhead,
                         ifileReadAheadLength, ifileBufferSize, false, comparator, 
                         reporter, null).merge(keyClass, valueClass,
                                         mergeFactor, tmpDir,
                                         readsCounter, writesCounter,
                                         bytesReadCounter,
                                         mergePhase);
}
 
开发者ID:apache,项目名称:tez,代码行数:23,代码来源:TezMerger.java

示例11: DiskSegment

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
public DiskSegment(FileSystem fs, Path file,
    long segmentOffset, long segmentLength, CompressionCodec codec,
    boolean ifileReadAhead, int ifileReadAheadLength, int bufferSize,
    boolean preserve, TezCounter mergedMapOutputsCounter)
throws IOException {
  super(null, mergedMapOutputsCounter);
  this.fs = fs;
  this.file = file;
  this.codec = codec;
  this.preserve = preserve;
  this.ifileReadAhead = ifileReadAhead;
  this.ifileReadAheadLength =ifileReadAheadLength;
  this.bufferSize = bufferSize;

  this.segmentOffset = segmentOffset;
  this.segmentLength = segmentLength;
}
 
开发者ID:apache,项目名称:tez,代码行数:18,代码来源:TezMerger.java

示例12: testInterruptOnNext

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
@Test(timeout = 5000)
public void testInterruptOnNext() throws IOException, InterruptedException {
  ShuffleManager shuffleManager = mock(ShuffleManager.class);

  // Simulate an interrupt while waiting for the next fetched input.
  doThrow(new InterruptedException()).when(shuffleManager).getNextInput();
  TezCounters counters = new TezCounters();
  TezCounter inputRecords = counters.findCounter(TaskCounter.INPUT_RECORDS_PROCESSED);
  UnorderedKVReader<Text, Text> reader =
      new UnorderedKVReader<Text, Text>(shuffleManager, defaultConf, null, false, -1, -1,
          inputRecords, mock(InputContext.class));

  try {
    reader.next();
    fail("No data available to reader. Should not be able to access any record");
  } catch (IOInterruptedException e) {
    // Expected exception. Any other should fail the test.
  }
}
 
开发者ID:apache,项目名称:tez,代码行数:20,代码来源:TestUnorderedKVReader.java

示例13: testEmptyDataWithPipelinedShuffle

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
@Test
  public void testEmptyDataWithPipelinedShuffle() throws IOException {
    this.numOutputs = 1;
    this.initialAvailableMem = 1 *1024 * 1024;
    conf.setBoolean(TezRuntimeConfiguration.TEZ_RUNTIME_ENABLE_FINAL_MERGE_IN_OUTPUT, false);
    conf.setInt(TezRuntimeConfiguration
        .TEZ_RUNTIME_PIPELINED_SORTER_MIN_BLOCK_SIZE_IN_MB, 1);
    PipelinedSorter sorter = new PipelinedSorter(this.outputContext, conf, numOutputs,
        initialAvailableMem);

    writeData(sorter, 0, 1<<20);

    // final merge is disabled. Final output file would not be populated in this case.
    assertTrue(sorter.finalOutputFile == null);
    TezCounter numShuffleChunks = outputContext.getCounters().findCounter(TaskCounter.SHUFFLE_CHUNK_COUNT);
//    assertTrue(sorter.getNumSpills() == numShuffleChunks.getValue());
    conf.setBoolean(TezRuntimeConfiguration.TEZ_RUNTIME_ENABLE_FINAL_MERGE_IN_OUTPUT, true);

  }
 
开发者ID:apache,项目名称:tez,代码行数:20,代码来源:TestPipelinedSorter.java

示例14: testExceedsKVWithPipelinedShuffle

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
@Test
public void testExceedsKVWithPipelinedShuffle() throws IOException {
  this.numOutputs = 1;
  this.initialAvailableMem = 1 *1024 * 1024;
  conf.setBoolean(TezRuntimeConfiguration.TEZ_RUNTIME_ENABLE_FINAL_MERGE_IN_OUTPUT, false);
  conf.setInt(TezRuntimeConfiguration
      .TEZ_RUNTIME_PIPELINED_SORTER_MIN_BLOCK_SIZE_IN_MB, 1);
  PipelinedSorter sorter = new PipelinedSorter(this.outputContext, conf, numOutputs,
      initialAvailableMem);

  writeData(sorter, 5, 1<<20);

  // final merge is disabled. Final output file would not be populated in this case.
  assertTrue(sorter.finalOutputFile == null);
  TezCounter numShuffleChunks = outputContext.getCounters().findCounter(TaskCounter.SHUFFLE_CHUNK_COUNT);
  assertTrue(sorter.getNumSpills() == numShuffleChunks.getValue());
  conf.setBoolean(TezRuntimeConfiguration.TEZ_RUNTIME_ENABLE_FINAL_MERGE_IN_OUTPUT, true);
}
 
开发者ID:apache,项目名称:tez,代码行数:19,代码来源:TestPipelinedSorter.java

示例15: createEmptyIterator

import org.apache.tez.common.counters.TezCounter; //导入依赖的package包/类
@SuppressWarnings("unchecked")
private ValuesIterator createEmptyIterator(boolean inMemory)
    throws IOException, InterruptedException {
  if (!inMemory) {
    streamPaths = new Path[0];
    //This will return EmptyIterator
    rawKeyValueIterator =
        TezMerger.merge(conf, fs, keyClass, valClass, null,
            false, -1, 1024, streamPaths, false, mergeFactor, tmpDir, comparator,
            new ProgressReporter(), null, null, null, null);
  } else {
    List<TezMerger.Segment> segments = Lists.newLinkedList();
    //This will return EmptyIterator
    rawKeyValueIterator =
        TezMerger.merge(conf, fs, keyClass, valClass, segments, mergeFactor, tmpDir,
            comparator, new ProgressReporter(), new GenericCounter("readsCounter", "y"),
            new GenericCounter("writesCounter", "y1"),
            new GenericCounter("bytesReadCounter", "y2"), new Progress());
  }
  return new ValuesIterator(rawKeyValueIterator, comparator,
      keyClass, valClass, conf, (TezCounter) new GenericCounter("inputKeyCounter", "y3"),
      (TezCounter) new GenericCounter("inputValueCounter", "y4"));
}
 
开发者ID:apache,项目名称:tez,代码行数:24,代码来源:TestValuesIterator.java


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