Package org.apache.flink.runtime.io.disk.iomanager

Examples of org.apache.flink.runtime.io.disk.iomanager.IOManager


  public void prepare() throws Exception{
    final TaskConfig config = this.taskContext.getTaskConfig();
   
    // obtain task manager's memory manager and I/O manager
    final MemoryManager memoryManager = this.taskContext.getMemoryManager();
    final IOManager ioManager = this.taskContext.getIOManager();
   
    // set up memory and I/O parameters
    final double fractionAvailableMemory = config.getRelativeMemoryDriver();
    final int numPages = memoryManager.computeNumberOfPages(fractionAvailableMemory);
   
View Full Code Here


        this.libraryCacheManager = new BlobLibraryCacheManager(new BlobCache
            (blobServerAddress), GlobalConfiguration.getConfiguration());
      }
    }
    this.ioManager = new IOManager(tmpDirPaths);
   
    // start the heart beats
    {
      final long interval = GlobalConfiguration.getInteger(
          ConfigConstants.TASK_MANAGER_HEARTBEAT_INTERVAL_KEY,
View Full Code Here

    this.pairBuildSideComparator = new IntPairComparator();
    this.pairProbeSideComparator = new IntPairComparator();
    this.pairComparator = new IntPairPairComparator();
   
    this.memManager = new DefaultMemoryManager(32 * 1024 * 1024,1);
    this.ioManager = new IOManager();
  }
View Full Code Here

      fail("Memory for the Join could not be provided.");
      return;
    }
   
    // create the I/O access for spilling
    final IOManager ioManager = new IOManager();
   
    // ----------------------------------------------------------------------------------------
   
    final MutableHashTable<IntPair, IntPair> join = new MutableHashTable<IntPair, IntPair>(
      this.pairBuildSideAccesssor, this.pairProbeSideAccesssor,
View Full Code Here

      fail("Memory for the Join could not be provided.");
      return;
    }
   
    // create the I/O access for spilling
    IOManager ioManager = new IOManager();
   
    // create the map for validating the results
    HashMap<Integer, Long> map = new HashMap<Integer, Long>(NUM_KEYS);
   
    // ----------------------------------------------------------------------------------------
View Full Code Here

      fail("Memory for the Join could not be provided.");
      return;
    }
   
    // create the I/O access for spilling
    IOManager ioManager = new IOManager();
   
    // create the map for validating the results
    HashMap<Integer, Long> map = new HashMap<Integer, Long>(NUM_KEYS);
   
    // ----------------------------------------------------------------------------------------
View Full Code Here

   
    final long totalMem = Math.max(memory, 0) + (Math.max(maxNumSorters, 0) * perSortMemory);
   
    this.perSortMem = perSortMemory;
    this.perSortFractionMem = (double)perSortMemory/totalMem;
    this.ioManager = new IOManager();
    this.memManager = totalMem > 0 ? new DefaultMemoryManager(totalMem,1) : null;
   
    this.inputs = new ArrayList<MutableObjectIterator<Record>>();
    this.comparators = new ArrayList<TypeComparator<Record>>();
    this.sorters = new ArrayList<UnilateralSortMerger<Record>>();
View Full Code Here

    this.taskConfiguration = new Configuration();
    this.inputs = new LinkedList<InputGate<Record>>();
    this.outputs = new LinkedList<OutputGate>();

    this.memManager = new DefaultMemoryManager(memorySize, 1);
    this.ioManager = new IOManager(System.getProperty("java.io.tmpdir"));
    this.inputSplitProvider = inputSplitProvider;
    this.mockBuffer = new Buffer(new MemorySegment(new byte[bufferSize]), bufferSize, null);
  }
View Full Code Here

  @SuppressWarnings("unchecked")
  @Before
  public void beforeTest() {
    this.memoryManager = new DefaultMemoryManager(MEMORY_SIZE, 1);
    this.ioManager = new IOManager();
   
    this.pactRecordSerializer = RecordSerializerFactory.get();
    this.pactRecordComparator = new RecordComparator(new int[] {0}, new Class[] {TestData.Key.class});
  }
View Full Code Here

    this.comparator1 = new RecordComparator(new int[] {0}, new Class[]{TestData.Key.class});
    this.comparator2 = new RecordComparator(new int[] {0}, new Class[]{TestData.Key.class});
    this.pairComparator = new RecordPairComparator(new int[] {0}, new int[] {0}, new Class[]{TestData.Key.class});
   
    this.memoryManager = new DefaultMemoryManager(MEMORY_SIZE, 1);
    this.ioManager = new IOManager();
  }
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.io.disk.iomanager.IOManager

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.