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

org.apache.flink.cdc.common.data.GenericMapData Maven / Gradle / Ivy

/*
 * 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.cdc.common.data;

import org.apache.flink.cdc.common.annotation.PublicEvolving;
import org.apache.flink.cdc.common.types.MapType;

import java.util.Map;
import java.util.Objects;

/**
 * An internal data structure representing data of {@link MapType}.
 *
 * 

{@link GenericMapData} is a generic implementation of {@link MapData} which wraps regular Java * maps. * *

Note: All keys and values of this data structure must be internal data structures. All keys * must be of the same type; same for values. See {@link RecordData} for more information about must * be of the same type; same for values. See {@link RecordData} for more information about internal * data structures. * *

Both keys and values can contain null for representing nullability. */ @PublicEvolving public final class GenericMapData implements MapData { private final Map map; /** * Creates an instance of {@link GenericMapData} using the given Java map. * *

Note: All keys and values of the map must be internal data structures. */ public GenericMapData(Map map) { this.map = map; } /** * Returns the value to which the specified key is mapped, or {@code null} if this map contains * no mapping for the key. The returned value is in internal data structure. */ public Object get(Object key) { return map.get(key); } @Override public int size() { return map.size(); } @Override public ArrayData keyArray() { Object[] keys = map.keySet().toArray(); return new GenericArrayData(keys); } @Override public ArrayData valueArray() { Object[] values = map.values().toArray(); return new GenericArrayData(values); } @Override public boolean equals(Object o) { if (o == this) { return true; } if (!(o instanceof GenericMapData)) { return false; } // deepEquals for values of byte[] return deepEquals(map, ((GenericMapData) o).map); } private static boolean deepEquals(Map m1, Map m2) { // copied from HashMap.equals but with deepEquals comparison if (m1.size() != m2.size()) { return false; } try { for (Map.Entry e : m1.entrySet()) { K key = e.getKey(); V value = e.getValue(); if (value == null) { if (!(m2.get(key) == null && m2.containsKey(key))) { return false; } } else { if (!Objects.deepEquals(value, m2.get(key))) { return false; } } } } catch (ClassCastException | NullPointerException unused) { return false; } return true; } @Override public int hashCode() { int result = 0; for (Object key : map.keySet()) { // only include key because values can contain byte[] result += 31 * Objects.hashCode(key); } return result; } @Override public String toString() { return map.toString(); } }





© 2015 - 2025 Weber Informatics LLC | Privacy Policy