Package org.apache.flink.core.memory

Examples of org.apache.flink.core.memory.DataInputView


      try {
        for (int n = 0; n < NUM_ITERATIONS; n++) {
          DataOutputView writeEnd = backChannel.getWriteEnd();
          readInputFromDataChannel();
          Thread.sleep(random.nextInt(10));
          DataInputView inputView = Mockito.mock(DataInputView.class);
          actionLog.add("tail writes in iteration " + n);
          writeEnd.write(inputView, 1);
          backChannel.notifyOfEndOfSuperstep();
        }
      } catch (Exception e) {
View Full Code Here


      generator.next(rec);
      rec.write(outView);
    }
   
    // create the reader input view
    DataInputView inView = outView.flip();
    generator.reset();
   
    // read and re-generate all records and compare them
    final Record readRec = new Record();
    for (int i = 0; i < NUM_PAIRS_INMEM; i++) {
View Full Code Here

      generator.next(rec);
      rec.write(outView);
    }
   
    // create the reader input view
    DataInputView inView = outView.flip();
    generator.reset();
   
    // read and re-generate all records and compare them
    final Record readRec = new Record();
    try {
View Full Code Here

      generator.next(rec);
      rec.write(outView);
    }
   
    // create the reader input view
    DataInputView inView = outView.flip();
    generator.reset();
   
    // read and re-generate all records and compare them
    final Record readRec = new Record();
    for (int i = 0; i < NUM_PAIRS_EXTERNAL; i++) {
View Full Code Here

      generator.next(rec);
      rec.write(outView);
    }
   
    // create the reader input view
    DataInputView inView = outView.flip();
    generator.reset();
   
    // read and re-generate all records and compare them
    final Record readRec = new Record();
    try {
View Full Code Here

    }
   
    if (this.exception != null) {
      throw new RuntimeException("An error occurred creating the temp table.", this.exception);
    } else if (this.writingDone) {
      final DataInputView in = this.buffer.flip();
      return new InputViewIterator<T>(in, this.serializer);
    } else {
      return null;
    }
  }
View Full Code Here

      // instantiate all aggregators and register them at the iteration global registry
      aggregatorRegistry = new RuntimeAggregatorRegistry(config.getIterationAggregators
          (getUserCodeClassLoader()));
      IterationAggregatorBroker.instance().handIn(brokerKey, aggregatorRegistry);

      DataInputView superstepResult = null;

      while (this.running && !terminationRequested()) {

        if (log.isInfoEnabled()) {
          log.info(formatLogString("starting iteration [" + currentIteration() + "]"));
View Full Code Here

TOP

Related Classes of org.apache.flink.core.memory.DataInputView

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.