All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.apache.flink.runtime.state.gemini.engine.memstore.SegmentKMapImpl Maven / Gradle / Ivy

There is a newer version: 1.5.1
Show newest version
/*
 * Licensed to the Apache Software Foundation (ASF) under one
 * or more contributor license agreements.  See the NOTICE file
 * distributed with this work for additional information
 * regarding copyright ownership.  The ASF licenses this file
 * to you under the Apache License, Version 2.0 (the
 * "License"); you may not use this file except in compliance
 * with the License.  You may obtain a copy of the License at
 *
 *     http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing, software
 * distributed under the License is distributed on an "AS IS" BASIS,
 * WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
 * See the License for the specific language governing permissions and
 * limitations under the License.
 */

package org.apache.flink.runtime.state.gemini.engine.memstore;

import org.apache.flink.api.common.typeutils.TypeSerializer;
import org.apache.flink.runtime.state.gemini.engine.GRegionContext;
import org.apache.flink.runtime.state.gemini.engine.page.GValueType;
import org.apache.flink.runtime.state.gemini.engine.page.PageSerdeFlink2Key;
import org.apache.flink.runtime.state.gemini.engine.page.bmap.GComparator;
import org.apache.flink.runtime.state.gemini.engine.utils.SeqIDUtils;

import java.util.HashMap;
import java.util.Map;
import java.util.TreeMap;

/**
 * SegmentKMapImpl. support HashMap and SortedMap.
 */
public class SegmentKMapImpl implements SegmentKMap {
	private final long segmentID;
	private final GRegionContext gRegionContext;
	private final long version;
	private final Map> dataMap;
	private int recordCount = 0;
	private final GComparator comparator;

	private boolean writeCopy;

	private TypeSerializer keySerializer;

	private TypeSerializer mkSerializer;

	private TypeSerializer mvSerializer;

	@SuppressWarnings("unchecked")
	public SegmentKMapImpl(long segmentID, GRegionContext gRegionContext, GComparator comparator) {
		this.segmentID = segmentID;
		this.gRegionContext = gRegionContext;
		this.dataMap = new HashMap<>();
		this.version = gRegionContext.getGContext().getCurVersion();
		this.comparator = comparator;
		this.writeCopy = gRegionContext.getGContext().getGConfiguration().isWriteCopy();
		this.keySerializer = gRegionContext.getPageSerdeFlink().getKeySerde();
		this.mkSerializer = ((PageSerdeFlink2Key) gRegionContext.getPageSerdeFlink()).getKey2Serde();
		this.mvSerializer = gRegionContext.getPageSerdeFlink().getValueSerde();
	}

	@SuppressWarnings("unchecked")
	public SegmentKMapImpl(
		long segmentID, GRegionContext gRegionContext, Map> dataMap, GComparator comparator) {
		this.segmentID = segmentID;
		this.gRegionContext = gRegionContext;
		this.dataMap = dataMap;
		this.version = gRegionContext.getGContext().getCurVersion();
		this.comparator = comparator;
		this.writeCopy = gRegionContext.getGContext().getGConfiguration().isWriteCopy();
		this.keySerializer = gRegionContext.getPageSerdeFlink().getKeySerde();
		this.mkSerializer = ((PageSerdeFlink2Key) gRegionContext.getPageSerdeFlink()).getKey2Serde();
		this.mvSerializer = gRegionContext.getPageSerdeFlink().getValueSerde();
	}

	@Override
	public void add(K key, MK mkey, MV mvalue) {
		GSValueMap gmap = getOrCreateMap(key);
		long seqID = gRegionContext.getNextSeqID();
		internalAdd(mkey, mvalue, gmap, seqID);
		updateMapSeqID(gmap, seqID);
	}

	private void internalAdd(MK mkey, MV mvalue, GSValueMap gmap, long seqID) {
		// TODO no need to copy key if the mapping has existed
		if (gmap.getValue().put(copyMKIfNeeded(mkey),
			GSValue.of(copyMVIfNeeded(mvalue), GValueType.PutValue, seqID)) == null) {
			recordCount++;
			gRegionContext.getWriteBufferStats().addTotalRecordCount(1);
		}
	}

	@Override
	public void add(K key, Map map) {
		final GSValueMap gmap = getOrCreateMap(key);
		long seqID = gRegionContext.getNextSeqID();
		map.forEach((mk, mv) -> internalAdd(copyMKIfNeeded(mk), copyMVIfNeeded(mv), gmap, seqID));
		updateMapSeqID(gmap, seqID);
	}

	@Override
	public void remove(K key, MK mapKey) {
		// TODO no need to copy key if the mapping has existed
		GSValueMap gmap = dataMap.computeIfAbsent(copyKeyIfNeeded(key), (nothing) -> createAddMap());
		long seqID = gRegionContext.getNextSeqID();
		if (gmap.getValue() == null) {
			return;
		}
		gmap.getValue().put(copyMKIfNeeded(mapKey),
			GSValue.of(null, GValueType.Delete, seqID));
		updateMapSeqID(gmap, seqID);
	}

	@Override
	public void put(K key, Map> value) {
		GSValueMap gmap = createPutMap();
		long seqID = SeqIDUtils.INVALID_SEQID;
		for (Map.Entry> entry : value.entrySet()) {
			GSValue gsValue = entry.getValue();
			seqID = Math.max(seqID, gsValue.getSeqID());
			// TODO better way is to replace put(K, Map>) with put(K, Map)
			gsValue.setValue(copyMVIfNeeded(gsValue.getValue()));
			gmap.getValue().put(copyMKIfNeeded(entry.getKey()), gsValue);
		}
		GSValueMap old = dataMap.put(copyKeyIfNeeded(key), gmap);
		updateMapSeqID(gmap, seqID);
		int oldSize = (old == null || old.getValue() == null) ? 0 : old.getValue().size();
		int delta = value.size() - oldSize;
		recordCount = recordCount + delta;
		gRegionContext.getWriteBufferStats().addTotalRecordCount(delta);
	}

	@Override
	public GSValueMap get(K key) {
		return dataMap.get(key);
	}

	@Override
	public GSValue get(K key, MK mapKey) {
		GSValueMap gsValueMap = get(key);
		if (gsValueMap == null) {
			return null;
		}
		if (gsValueMap.getValueType() == GValueType.Delete) {
			return new GSValue<>(null, GValueType.Delete, gsValueMap.getSeqID());
		}
		GSValue result = gsValueMap.getValue().get(mapKey);
		if (result == null && gsValueMap.getValueType() == GValueType.PutMap) {
			//because this is a PutMap, so prior data is useless. we return DELETE to indicate this case.
			return new GSValue<>(null, GValueType.Delete, gsValueMap.getSeqID());
		}
		return result;
	}

	@Override
	public void removeKey(K key) {
		GSValueMap gmap = createDeleteMap();
		long seqID = gRegionContext.getNextSeqID();
		updateMapSeqID(gmap, seqID);
		// TODO no need to copy key if the mapping has existed
		dataMap.put(copyKeyIfNeeded(key), gmap);
	}

	@Override
	public long getSegmentID() {
		return this.segmentID;
	}

	@Override
	public int getRecordCount() {
		return this.recordCount;
	}

	@Override
	public long getVersion() {
		return this.version;
	}

	@Override
	public Segment>> copySegment() {
		Map> copyMap = new HashMap<>();
		for (Map.Entry> entry : dataMap.entrySet()) {
			copyMap.put(entry.getKey(), entry.getValue().copyGSValueMap());
		}
		return new SegmentKMapImpl<>(-1L, this.gRegionContext, copyMap, this.comparator);
	}

	@Override
	public Map getData() {
		return dataMap;
	}

	private GSValueMap getOrCreateMap(K key) {
		GSValueMap gmap = dataMap.get(key);
		if (gmap == null || gmap.getSeqID() < gRegionContext.getRemoveAllSeqID()) {
			gmap = createAddMap();
			dataMap.put(copyKeyIfNeeded(key), gmap);
		} else if (gmap.getValueType() == GValueType.Delete) {
			gmap = createPutMap();
			dataMap.put(copyKeyIfNeeded(key), gmap);
		}
		return gmap;
	}

	private GSValueMap createAddMap() {
		return GSValueMap.of(comparator != null ? new TreeMap<>(comparator.getJDKCompactor()) : new HashMap<>(),
			GValueType.AddMap, SeqIDUtils.INVALID_SEQID);
	}

	private GSValueMap createPutMap() {
		return GSValueMap.of(comparator != null ? new TreeMap<>(comparator.getJDKCompactor()) : new HashMap<>(),
			GValueType.PutMap, SeqIDUtils.INVALID_SEQID);
	}

	private GSValueMap createDeleteMap() {
		return GSValueMap.of(null, GValueType.Delete, SeqIDUtils.INVALID_SEQID);
	}

	private void updateMapSeqID(GSValueMap gsValueMap, long seqID) {
		gsValueMap.setSeqID(seqID);
	}

	public Map> getDataMap() {
		return dataMap;
	}

	private K copyKeyIfNeeded(K key) {
		return writeCopy ? keySerializer.copy(key) : key;
	}

	private MK copyMKIfNeeded(MK mk) {
		return writeCopy ? mkSerializer.copy(mk) : mk;
	}

	private MV copyMVIfNeeded(MV mv) {
		return writeCopy ? mvSerializer.copy(mv) : mv;
	}
}




© 2015 - 2024 Weber Informatics LLC | Privacy Policy