Package org.apache.flink.runtime.memorymanager

Examples of org.apache.flink.runtime.memorymanager.DefaultMemoryManager


      try {
        @SuppressWarnings("unused")
        final boolean lazyAllocation = GlobalConfiguration.getBoolean(ConfigConstants.TASK_MANAGER_MEMORY_LAZY_ALLOCATION_KEY,
          ConfigConstants.DEFAULT_TASK_MANAGER_MEMORY_LAZY_ALLOCATION);
       
        this.memoryManager = new DefaultMemoryManager(memorySize, this.numberOfSlots, pageSize);
      } catch (Throwable t) {
        LOG.error("Unable to initialize memory manager with " + (memorySize >>> 20) + " megabytes of memory.", t);
        throw new Exception("Unable to initialize memory manager.", t);
      }
    }
View Full Code Here


    this.pairProbeSideAccesssor = new IntPairSerializer();
    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

    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.jobConfiguration = new Configuration();
    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

  private TypeComparator<IntPair> comparator;


  @Before
  public void beforeTest() {
    this.memoryManager = new DefaultMemoryManager(MEMORY_SIZE, MEMORY_PAGE_SIZE);
    this.serializer = new IntPairSerializer();
    this.comparator = new IntPairComparator();
  }
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.serializer2 = RecordSerializer.get();
    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

  private List<Record> objects;

  @Before
  public void startup() {
    // set up IO and memory manager
    this.memman = new DefaultMemoryManager(MEMORY_CAPACITY, 1);
   
    // create test objects
    this.objects = new ArrayList<Record>(20000);
    for (int i = 0; i < NUM_VALUES; ++i) {
      this.objects.add(new Record(new IntValue(i)));
View Full Code Here


  @Before
  public void startup() {
    // set up IO and memory manager
    this.memman = new DefaultMemoryManager(MEMORY_CAPACITY, 32 * 1024);
    this.ioman = new IOManager();

    // create test objects
    final ArrayList<Record> objects = new ArrayList<Record>(NUM_TESTRECORDS);

View Full Code Here

    this.serializer2 = RecordSerializerFactory.get();
    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.pairComparator11 = new RecordPairComparator(new int[] {0}, new int[] {0}, new Class[] {TestData.Key.class});
   
    this.memoryManager = new DefaultMemoryManager(MEMORY_SIZE, PAGE_SIZE);
    this.ioManager = new IOManager();
  }
View Full Code Here

TOP

Related Classes of org.apache.flink.runtime.memorymanager.DefaultMemoryManager

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.