java.util.LinkedHashMap#putAll ( )源码实例Demo

下面列出了java.util.LinkedHashMap#putAll ( ) 实例代码,或者点击链接到github查看源代码,也可以在右侧发表评论。

public DocumentFilterList mergeWith(@NonNull final DocumentFilterList other)
{
	if (isEmpty())
	{
		return other;
	}
	else if (other.isEmpty())
	{
		return this;
	}
	else
	{
		final LinkedHashMap<String, DocumentFilter> filtersByIdNew = new LinkedHashMap<>(this.filtersById);
		filtersByIdNew.putAll(other.filtersById);

		return ofMap(filtersByIdNew);
	}
}
 
源代码2 项目: open-cloud   文件: JdbcRouteLocator.java
/**
 * 加载路由配置
 *
 * @return
 */
@Override
protected Map<String, ZuulProperties.ZuulRoute> locateRoutes() {
    LinkedHashMap<String, ZuulProperties.ZuulRoute> routesMap = Maps.newLinkedHashMap();
    routesMap.putAll(super.locateRoutes());
    //从db中加载路由信息
    routesMap.putAll(loadRoutes());
    //优化一下配置
    LinkedHashMap<String, ZuulProperties.ZuulRoute> values = Maps.newLinkedHashMap();
    for (Map.Entry<String, ZuulProperties.ZuulRoute> entry : routesMap.entrySet()) {
        String path = entry.getKey();
        // Prepend with slash if not already present.
        if (!path.startsWith("/")) {
            path = "/" + path;
        }
        if (StringUtils.hasText(this.properties.getPrefix())) {
            path = this.properties.getPrefix() + path;
            if (!path.startsWith("/")) {
                path = "/" + path;
            }
        }
        values.put(path, entry.getValue());
    }
    return values;
}
 
源代码3 项目: pacbot   文件: CommonUtils.java
/**
 * 
 * @param notation
 * @param nestedMap
 * @return
 */
@SuppressWarnings("unchecked")
public static LinkedHashMap<String, Object> flatNestedLinkedHashMap(String notation, Map<String, Object> nestedMap) {
	LinkedHashMap<String, Object> flatNestedMap = new LinkedHashMap<String, Object>();
	String prefixKey = notation != null ? notation + "." : "";
	for (Map.Entry<String, Object> entry : nestedMap.entrySet()) {
		if (entry.getValue() instanceof String || entry.getValue() instanceof Long || entry.getValue() instanceof Integer  || entry.getValue() instanceof Float || entry.getValue() instanceof Double) {
			flatNestedMap.put(prefixKey + entry.getKey(), entry.getValue());
		}
		if (entry.getValue() instanceof Map) {
			flatNestedMap.putAll(flatNestedMap(prefixKey + entry.getKey(), (Map<String, Object>) entry.getValue()));
		}
		if (entry.getValue() instanceof ArrayList) {
			Gson gson = new Gson();
			flatNestedMap.put("list",gson.toJson(entry.getValue()));
			
		}
	}
	return flatNestedMap;
}
 
源代码4 项目: hive-third-functions   文件: UDFMapConcatTest.java
@Test
public void testMapConcat() throws Exception {
    UDFMapConcat udf = new UDFMapConcat();
    ObjectInspector leftMapOI = ObjectInspectorFactory.getStandardMapObjectInspector(PrimitiveObjectInspectorFactory.javaStringObjectInspector, PrimitiveObjectInspectorFactory.javaStringObjectInspector);
    ObjectInspector rightMapOI = ObjectInspectorFactory.getStandardMapObjectInspector(PrimitiveObjectInspectorFactory.javaStringObjectInspector, PrimitiveObjectInspectorFactory.javaStringObjectInspector);
    ObjectInspector[] arguments = {leftMapOI, rightMapOI};
    udf.initialize(arguments);

    LinkedHashMap<String, String> leftMap = Maps.newLinkedHashMap();
    leftMap.putAll(ImmutableMap.<String, String>of("key1", "11", "key2", "12", "key3", "13"));
    LinkedHashMap<String, String> rightMap = Maps.newLinkedHashMap();
    rightMap.putAll(ImmutableMap.<String, String>of("key3", "21", "key4", "22", "key5", "23"));

    DeferredObject leftMapObj = new DeferredJavaObject(leftMap);
    DeferredObject rightMapObj = new DeferredJavaObject(rightMap);
    DeferredObject[] args = {leftMapObj, rightMapObj};
    LinkedHashMap<String, String> output = (LinkedHashMap<String, String>) udf.evaluate(args);
    LinkedHashMap<String, String> expect = Maps.newLinkedHashMap();
    expect.putAll(ImmutableMap.<String, String>of("key1", "11", "key2", "12", "key3", "21", "key4", "22", "key5", "23"));

    Assert.assertEquals("map_concat() test", true, MapUtils.mapEquals(output, expect));
}
 
源代码5 项目: Taroco   文件: DynamicRouteLocator.java
/**
 * 重写路由配置
 *
 * @return 路由表
 */
@Override
protected LinkedHashMap<String, ZuulProperties.ZuulRoute> locateRoutes() {
    //读取properties配置、eureka默认配置
    LinkedHashMap<String, ZuulProperties.ZuulRoute> routesMap = new LinkedHashMap<>(super.locateRoutes());
    log.debug("初始默认的路由配置完成");
    routesMap.putAll(locateRoutesFromCache());
    LinkedHashMap<String, ZuulProperties.ZuulRoute> values = new LinkedHashMap<>();
    for (Map.Entry<String, ZuulProperties.ZuulRoute> entry : routesMap.entrySet()) {
        String path = entry.getKey();
        if (!path.startsWith("/")) {
            path = "/" + path;
        }
        if (StrUtil.isNotBlank(this.properties.getPrefix())) {
            path = this.properties.getPrefix() + path;
            if (!path.startsWith("/")) {
                path = "/" + path;
            }
        }
        values.put(path, entry.getValue());
    }
    return values;
}
 
源代码6 项目: hive-third-functions   文件: UDFMapBuildTest.java
@Test
public void testMapBuild() throws Exception {
    UDFMapBuild udf = new UDFMapBuild();
    ObjectInspector keyArrayOI = ObjectInspectorFactory.getStandardListObjectInspector(PrimitiveObjectInspectorFactory.javaStringObjectInspector);
    ObjectInspector valueArrayOI = ObjectInspectorFactory.getStandardListObjectInspector(PrimitiveObjectInspectorFactory.javaStringObjectInspector);
    ObjectInspector[] arguments = {keyArrayOI, valueArrayOI};
    udf.initialize(arguments);

    List<String> keyArray = ImmutableList.of("key1", "key2", "key3");
    List<String> valueArray = ImmutableList.of("value1", "value2", "value3");
    DeferredObject keyArrayObj = new DeferredJavaObject(keyArray);
    DeferredObject valueArrayObj = new DeferredJavaObject(valueArray);
    DeferredObject[] args = {keyArrayObj, valueArrayObj};
    LinkedHashMap<String, String> output = (LinkedHashMap<String, String>) udf.evaluate(args);
    LinkedHashMap<String, String> expect = Maps.newLinkedHashMap();
    expect.putAll(ImmutableMap.<String, String>of("key1", "value1", "key2", "value2", "key3", "value3"));

    Assert.assertEquals("map_build() test", true, MapUtils.mapEquals(output, expect));
}
 
源代码7 项目: kite   文件: ClassPath.java
@VisibleForTesting static ImmutableMap<URI, ClassLoader> getClassPathEntries(
    ClassLoader classloader) {
  LinkedHashMap<URI, ClassLoader> entries = Maps.newLinkedHashMap();
  // Search parent first, since it's the order ClassLoader#loadClass() uses.
  ClassLoader parent = classloader.getParent();
  if (parent != null) {
    entries.putAll(getClassPathEntries(parent));
  }
  if (classloader instanceof URLClassLoader) {
    URLClassLoader urlClassLoader = (URLClassLoader) classloader;
    for (URL entry : urlClassLoader.getURLs()) {
      URI uri;
      try {
        uri = entry.toURI();
      } catch (URISyntaxException e) {
        throw new IllegalArgumentException(e);
      }
      if (!entries.containsKey(uri)) {
        entries.put(uri, classloader);
      }
    }
  }
  return ImmutableMap.copyOf(entries);
}
 
源代码8 项目: openemm   文件: ReflectionTableParser.java
private Map<String, ColumnDefinition> getColumnDefinitions(Object object) {
    LinkedHashMap<String, ColumnDefinition> columnDefinitions = new LinkedHashMap<>();
    columnDefinitions.putAll(getColumnDefinitionsFromMethods(object));
    columnDefinitions.putAll(getColumnDefinitionsFromFields(object));

    return columnDefinitions;
}
 
/**
 * Gets api parameters.
 *
 * @param method the method
 * @return the api parameters
 */
private Map<String, io.swagger.v3.oas.annotations.Parameter> getApiParameters(Method method) {
	Class<?> declaringClass = method.getDeclaringClass();

	Set<io.swagger.v3.oas.annotations.Parameters> apiParametersDoc = AnnotatedElementUtils
			.findAllMergedAnnotations(method, io.swagger.v3.oas.annotations.Parameters.class);
	LinkedHashMap<String, io.swagger.v3.oas.annotations.Parameter> apiParametersMap = apiParametersDoc.stream()
			.flatMap(x -> Stream.of(x.value())).collect(Collectors.toMap(io.swagger.v3.oas.annotations.Parameter::name, x -> x, (e1, e2) -> e2,
					LinkedHashMap::new));

	Set<io.swagger.v3.oas.annotations.Parameters> apiParametersDocDeclaringClass = AnnotatedElementUtils
			.findAllMergedAnnotations(declaringClass, io.swagger.v3.oas.annotations.Parameters.class);
	LinkedHashMap<String, io.swagger.v3.oas.annotations.Parameter> apiParametersDocDeclaringClassMap = apiParametersDocDeclaringClass.stream()
			.flatMap(x -> Stream.of(x.value())).collect(Collectors.toMap(io.swagger.v3.oas.annotations.Parameter::name, x -> x, (e1, e2) -> e2,
					LinkedHashMap::new));
	apiParametersMap.putAll(apiParametersDocDeclaringClassMap);

	Set<io.swagger.v3.oas.annotations.Parameter> apiParameterDoc = AnnotatedElementUtils
			.findAllMergedAnnotations(method, io.swagger.v3.oas.annotations.Parameter.class);
	LinkedHashMap<String, io.swagger.v3.oas.annotations.Parameter> apiParameterDocMap = apiParameterDoc.stream()
			.collect(Collectors.toMap(io.swagger.v3.oas.annotations.Parameter::name, x -> x, (e1, e2) -> e2,
					LinkedHashMap::new));
	apiParametersMap.putAll(apiParameterDocMap);

	Set<io.swagger.v3.oas.annotations.Parameter> apiParameterDocDeclaringClass = AnnotatedElementUtils
			.findAllMergedAnnotations(declaringClass, io.swagger.v3.oas.annotations.Parameter.class);
	LinkedHashMap<String, io.swagger.v3.oas.annotations.Parameter> apiParameterDocDeclaringClassMap = apiParameterDocDeclaringClass.stream()
			.collect(Collectors.toMap(io.swagger.v3.oas.annotations.Parameter::name, x -> x, (e1, e2) -> e2,
					LinkedHashMap::new));
	apiParametersMap.putAll(apiParameterDocDeclaringClassMap);

	return apiParametersMap;
}
 
源代码10 项目: logsniffer   文件: GrokTextReader.java
@Override
public LinkedHashMap<String, FieldBaseTypes> getFieldTypes() throws FormatException {
	init();
	final LinkedHashMap<String, FieldBaseTypes> fields = super.getFieldTypes();
	fields.putAll(grokBean.getGrok(groksRegistry).getFieldTypes());
	if (overflowAttribute != null && !fields.containsKey(overflowAttribute)) {
		fields.put(overflowAttribute, FieldBaseTypes.STRING);
	}
	return fields;
}
 
源代码11 项目: InflatableDonkey   文件: PZFactory.java
ProtectionZone protectionZone(LinkedHashMap<KeyID, Key<ECPrivateKey>> keys, String protectionInfoTag,
        ProtectionInfo protectionInfo) {
    List<byte[]> masterKeys = assistant.masterKeys(protectionInfo, keys);
    masterKeys.forEach(u -> logger.trace("-- protectionZone() - master key: 0x{}", Hex.toHexString(u)));
    List<byte[]> decryptKeys = masterKeys.stream()
            .map(kdf::apply)
            .collect(toList());
    decryptKeys.forEach(u -> logger.trace("-- protectionZone() - decrypt key: 0x{}", Hex.toHexString(u)));

    // Ordering is important here. The latest protection zone should be iterated first.
    LinkedHashMap newKeys = keys(assistant.keys(protectionInfo, decryptKeys));
    newKeys.putAll(keys);
    return new ProtectionZone(unwrapKey, masterKeys, decryptKeys, newKeys, protectionInfoTag);
}
 
源代码12 项目: tez   文件: VertexImpl.java
protected void addTask(Task task) {
  synchronized (tasksSyncHandle) {
    if (lazyTasksCopyNeeded) {
      LinkedHashMap<TezTaskID, Task> newTasks = new LinkedHashMap<TezTaskID, Task>();
      newTasks.putAll(tasks);
      tasks = newTasks;
      lazyTasksCopyNeeded = false;
    }
  }
  tasks.put(task.getTaskId(), task);
  // TODO Metrics
  //metrics.waitingTask(task);
}
 
源代码13 项目: j2objc   文件: LinkedHashMapTest.java
public void test_removeEldestEntry_removeKey() {
    LinkedHashMap<String, String> m = new LinkedHashMap<String, String>() {
        @Override
        protected boolean removeEldestEntry(Entry<String, String> eldest) {
            int size = size();
            if (size > 2) {
                remove(eldest.getKey());
            }
            return false;
        }
    };
    m.putAll(createMap("K1", "V1", "K2", "V2", "K3", "V3", "K4", "V4"));
    assertEquals(createMap("K3", "V3", "K4", "V4"), m);
}
 
源代码14 项目: weex-uikit   文件: FunctionParser.java
private LinkedHashMap<K, V> definition() {
  LinkedHashMap<K, V> result = new LinkedHashMap<>();
  do {
    result.putAll(function());
  } while (lexer.getCurrentToken() == Token.FUNC_NAME);
  return result;
}
 
源代码15 项目: barleydb   文件: GenerateGrapqlSDL.java
private void addAllNodes(EntitySpec et, LinkedHashMap<String, FieldDefinition> fds, boolean inputFields) {
	if (et.getParentEntity() != null) {
		addAllNodes(et.getParentEntity(), fds, inputFields);
	}
	fds.putAll(et.getNodeSpecs().stream()
		.map( ns -> inputFields ? new InputFieldDefinition(ns) : new QueryFieldDefinition(ns))
		.collect(Collectors.toMap(FieldDefinition::getName, fd -> fd)));		
}
 
源代码16 项目: rice   文件: PropertiesMap.java
/**
 * Builds a HashMap containing all of the key,value pairs stored in this PropertyTree
 *
 * @return
 */
private Map collectEntries(String prefix, boolean flattenEntries) {
    LinkedHashMap entryMap = new LinkedHashMap();

    for (Iterator i = this.children.entrySet().iterator(); i.hasNext();) {
        Entry e = (Entry) i.next();
        PropertyTree child = (PropertyTree) e.getValue();
        String childKey = (String) e.getKey();

        // handle children with values
        if (child.hasDirectValue()) {
            String entryKey = (prefix == null) ? childKey : prefix + "." + childKey;
            String entryValue = child.getDirectValue();

            entryMap.put(entryKey, entryValue);
        }

        // handle children with children
        if (!flattenEntries && child.hasChildren()) {
            String childPrefix = (prefix == null) ? childKey : prefix + "." + childKey;

            entryMap.putAll(child.collectEntries(childPrefix, flattenEntries));
        }
    }

    return entryMap;
}
 
源代码17 项目: stategen   文件: XMLHelper.java
public LinkedHashMap<String,String> nodeNameAsAttributes(String nodeNameKey) {
	LinkedHashMap map = new LinkedHashMap();
    map.putAll(attributes);
    map.put(nodeNameKey, nodeName);
    return map;
}
 
源代码18 项目: logsniffer   文件: RegexFilter.java
@Override
public void filterKnownFields(final LinkedHashMap<String, FieldBaseTypes> knownFields) throws FormatException {
	knownFields.putAll(grokBean.getGrok(groksRegistry).getFieldTypes());

}
 
源代码19 项目: datacollector   文件: JdbcMetadataProcessor.java
@Override
protected void process(Record record, BatchMaker batchMaker) throws StageException {
  try {
    ELVars variables = getContext().createELVars();
    RecordEL.setRecordInContext(variables, record);
    TimeEL.setCalendarInContext(variables, Calendar.getInstance());
    TimeNowEL.setTimeNowInContext(variables, new Date());

    String schema = (schemaEL != null) ? elEvals.dbNameELEval.eval(variables, schemaEL, String.class) : null;
    String tableName = elEvals.tableNameELEval.eval(variables, tableNameEL, String.class);

    if (StringUtils.isEmpty(schema)) {
      schema = null;
    }

    // Obtain the record structure from current record
    LinkedHashMap<String, JdbcTypeInfo> recordStructure = JdbcMetastoreUtil.convertRecordToJdbcType(
        record,
        decimalDefaultsConfig.precisionAttribute,
        decimalDefaultsConfig.scaleAttribute,
        schemaWriter);

    if (recordStructure.isEmpty()) {
      batchMaker.addRecord(record);
      return;
    }

    LinkedHashMap<String, JdbcTypeInfo> tableStructure = null;
    try {
      tableStructure = tableCache.get(Pair.of(schema, tableName));
    } catch (ExecutionException e) {
      throw new JdbcStageCheckedException(JdbcErrors.JDBC_203, e.getMessage(), e);
    }

    if (tableStructure.isEmpty()) {
      // Create table
      schemaWriter.createTable(schema, tableName, recordStructure);
      tableCache.put(Pair.of(schema, tableName), recordStructure);
    } else {
      // Compare tables
      LinkedHashMap<String, JdbcTypeInfo> columnDiff = JdbcMetastoreUtil.getDiff(tableStructure, recordStructure);
      if (!columnDiff.isEmpty()) {
        LOG.trace("Detected drift for table {} - new columns: {}",
            tableName,
            StringUtils.join(columnDiff.keySet(), ",")
        );
        schemaWriter.alterTable(schema, tableName, columnDiff);
        tableStructure.putAll(columnDiff);
        tableCache.put(Pair.of(schema, tableName), tableStructure);
      }
    }

    batchMaker.addRecord(record);
  } catch (JdbcStageCheckedException error) {
    LOG.error("Error happened when processing record", error);
    LOG.trace("Record that caused the error: {}", record.toString());
    errorRecordHandler.onError(new OnRecordErrorException(record, error.getErrorCode(), error.getParams()));
  }
}
 
源代码20 项目: buck   文件: RuleKeyDifferTest.java
@Test
public void handlesDifferencesForBaseTypes()
    throws MaxDifferencesException, GraphTraversalException {
  Map<String, Value> onlyInOriginal = generateSampleValues(1, 1);
  Map<String, Value> changedInOriginal = generateSampleValues(2, 1);
  Map<String, Value> changedInNew = generateSampleValues(2, 2);
  Map<String, Value> common = generateSampleValues(3, 1);
  Map<String, Value> onlyInNew = generateSampleValues(4, 1);

  LinkedHashMap<String, Value> originalValues = new LinkedHashMap<>();
  originalValues.putAll(onlyInOriginal);
  originalValues.putAll(changedInOriginal);
  originalValues.putAll(common);

  LinkedHashMap<String, Value> newValues = new LinkedHashMap<>();
  newValues.putAll(onlyInNew);
  newValues.putAll(changedInNew);
  newValues.putAll(common);

  FullRuleKey originalRuleKey =
      new FullRuleKey("original_hash", "//:target1", "rule_type", originalValues);

  FullRuleKey newRuleKey = new FullRuleKey("new_hash", "//:target1", "rule_type", newValues);

  ParsedRuleKeyFile originalFile = createParsedFile(Paths.get("file1"), originalRuleKey);
  ParsedRuleKeyFile newFile = createParsedFile(Paths.get("file2"), newRuleKey);

  List<String> expectedLines =
      generateExpectedStrings(
          ImmutableList.<String>builder()
              .addAll(onlyInOriginal.keySet())
              .addAll(onlyInNew.keySet())
              .addAll(changedInOriginal.keySet())
              .build(),
          originalFile,
          newFile);

  differ.printDiff(originalFile, newFile);
  List<String> lines = Arrays.asList(stream.getOutputLines());

  Assert.assertEquals(expectedLines.size(), lines.size());
  Assert.assertEquals(expectedLines, lines);
}