Java 类com.google.common.collect.BiMap 实例源码

项目:CustomWorldGen    文件:GameData.java   
@SuppressWarnings("unchecked")
@Override
public void onCreate(Map<ResourceLocation, ?> slaveset, BiMap<ResourceLocation, ? extends IForgeRegistry<?>> registries)
{
    final ClearableObjectIntIdentityMap<IBlockState> idMap = new ClearableObjectIntIdentityMap<IBlockState>()
    {
        @SuppressWarnings("deprecation")
        @Override
        public int get(IBlockState key)
        {
            Integer integer = (Integer)this.identityMap.get(key);
            // There are some cases where this map is queried to serialize a state that is valid,
            //but somehow not in this list, so attempt to get real metadata. Doing this hear saves us 7 patches
            if (integer == null && key != null)
                integer = this.identityMap.get(key.getBlock().getStateFromMeta(key.getBlock().getMetaFromState(key)));
            return integer == null ? -1 : integer.intValue();
        }
    };
    ((Map<ResourceLocation,Object>)slaveset).put(BLOCKSTATE_TO_ID, idMap);
    final HashBiMap<Block, Item> map = HashBiMap.create();
    ((Map<ResourceLocation,Object>)slaveset).put(BLOCK_TO_ITEM, map);
}
项目:BaseClient    文件:SoundManager.java   
public SoundManager(SoundHandler p_i45119_1_, GameSettings p_i45119_2_)
{
    this.invPlayingSounds = ((BiMap)this.playingSounds).inverse();
    this.playingSoundPoolEntries = Maps.<ISound, SoundPoolEntry>newHashMap();
    this.categorySounds = HashMultimap.<SoundCategory, String>create();
    this.tickableSounds = Lists.<ITickableSound>newArrayList();
    this.delayedSounds = Maps.<ISound, Integer>newHashMap();
    this.playingSoundsStopTime = Maps.<String, Integer>newHashMap();
    this.sndHandler = p_i45119_1_;
    this.options = p_i45119_2_;

    try
    {
        SoundSystemConfig.addLibrary(LibraryLWJGLOpenAL.class);
        SoundSystemConfig.setCodec("ogg", CodecJOrbis.class);
    }
    catch (SoundSystemException soundsystemexception)
    {
        logger.error(LOG_MARKER, (String)"Error linking with the LibraryJavaSound plug-in", (Throwable)soundsystemexception);
    }
}
项目:n4js    文件:N4HeadlessCompiler.java   
private void configureResourceSetContainerState(final List<N4JSProject> allProjects) {
    // a container is a project.
    List<String> containers = new LinkedList<>();
    BiMap<String, N4JSProject> container2project = HashBiMap.create();

    // the URIs of all resources directly contained in a project/container.
    Multimap<String, URI> container2Uris = HashMultimap.create();

    for (N4JSProject project : allProjects) {
        String container = FileBasedWorkspace.N4FBPRJ + project.getLocation();
        container2project.put(container, project);
        containers.add(container);

        for (IN4JSSourceContainer sourceContainer : project.getSourceContainers()) {
            Iterables.addAll(container2Uris.get(container), sourceContainer);
        }
    }

    // Define the Mapping of Resources (URIs to Container === Projects),
    rsbAcs.configure(containers, container2Uris);
}
项目:cakes    文件:HashBiMapDemo.java   
/**
 * BiMap存储数据时出现冲突
 * 存储时,如果key相同,则会覆盖,则逆转后不会有问题
 * 存储时,如果key不同,value有相同,则逆转时会抛出异常IllegalArgumentException
 */
@Test
public void testConflictInsertKV() {
    // 存储相同key数据,此时会覆盖k1=v1
    BiMap<String, String> biMap1 = HashBiMap.create();
    biMap1.put("k1", "v1");
    biMap1.put("k1", "v2");
    System.out.println("biMap1: " + biMap1);

    // 获取的只有 v2=k1
    BiMap<String, String> inverseBiMap1 = biMap1.inverse();
    System.out.println("inverseBiMap1: " + inverseBiMap1);

    System.out.println("--------------------------------------");

    // 存储相同的value数据
    BiMap<String, String> biMap2 = HashBiMap.create();
    biMap2.put("k1", "v1");

    // 此时抛出异常 java.lang.IllegalArgumentException: value already present: v1
    biMap2.put("k2", "v1");
    System.out.println("biMap2: " + biMap2);

    BiMap<String, String> inverseBiMap2 = biMap2.inverse();
    System.out.println("inverseBiMap2: " + inverseBiMap2);
}
项目:DecompiledMinecraft    文件:SoundManager.java   
public SoundManager(SoundHandler p_i45119_1_, GameSettings p_i45119_2_)
{
    this.invPlayingSounds = ((BiMap)this.playingSounds).inverse();
    this.playingSoundPoolEntries = Maps.<ISound, SoundPoolEntry>newHashMap();
    this.categorySounds = HashMultimap.<SoundCategory, String>create();
    this.tickableSounds = Lists.<ITickableSound>newArrayList();
    this.delayedSounds = Maps.<ISound, Integer>newHashMap();
    this.playingSoundsStopTime = Maps.<String, Integer>newHashMap();
    this.sndHandler = p_i45119_1_;
    this.options = p_i45119_2_;

    try
    {
        SoundSystemConfig.addLibrary(LibraryLWJGLOpenAL.class);
        SoundSystemConfig.setCodec("ogg", CodecJOrbis.class);
    }
    catch (SoundSystemException soundsystemexception)
    {
        logger.error(LOG_MARKER, (String)"Error linking with the LibraryJavaSound plug-in", (Throwable)soundsystemexception);
    }
}
项目:BIMplatform    文件:IfcModel.java   
@SuppressWarnings("rawtypes")
private void fixOids(IdEObject idEObject, OidProvider oidProvider, BiMap<Long, IdEObject> temp) {
    if (idEObject == null) {
        return;
    }
    if (temp.containsValue(idEObject)) {
        return;
    }
    ((IdEObjectImpl) idEObject).setOid(oidProvider.newOid(idEObject.eClass()));
    if (objects.containsValue(idEObject)) {
        temp.put(idEObject.getOid(), idEObject);
    }
    for (EReference eReference : idEObject.eClass().getEAllReferences()) {
        Object val = idEObject.eGet(eReference);
        if (eReference.isMany()) {
            List list = (List) val;
            for (Object o : list) {
                fixOids((IdEObject) o, oidProvider, temp);
            }
        } else {
            fixOids((IdEObject) val, oidProvider, temp);
        }
    }
}
项目:CustomWorldGen    文件:GameData.java   
@Override
public void onSubstituteActivated(Map<ResourceLocation, ?> slaveset, Block original, Block replacement, ResourceLocation name)
{
    final BiMap<Block, Item> blockItemMap = (BiMap<Block, Item>)slaveset.get(BLOCK_TO_ITEM);
    if (blockItemMap.containsKey(original))
    {
        Item i = blockItemMap.get(original);
        if (i instanceof ItemBlock)
        {
            try
            {
                FinalFieldHelper.setField(blockField, i, replacement);
            }
            catch (Exception e)
            {
                throw Throwables.propagate(e);
            }
        }
        blockItemMap.forcePut(replacement,i);
    }
}
项目:Mixinite    文件:Mappings.java   
public Optional<MethodRef> getUnmappedMethodMapping(CtClass targetClass, CtMethod
        handleMethod) {
    BiMap<MethodRef, MethodRef> methodsInverted = methodRefs.inverse();
    String descriptor = InjectorPlugin.removeCallbackDescriptor(handleMethod.getMethodInfo2()
            .getDescriptor());
    for (Map.Entry<MethodRef, MethodRef> mapping : methodsInverted.entrySet()) {
        MethodRef key = mapping.getKey();
        if (targetClass.getName().replace('.', '/').equals(key.getOwner()) && handleMethod
                .getName
                ().equals
                (key
                .getName()) && descriptor.equals(key.getDesc())) {
            return Optional.of(mapping.getValue());
        }
    }
    return Optional.empty();
}
项目:rejoiner    文件:ProtoRegistry.java   
/** Applies the supplied modifications to the GraphQLTypes. */
private static BiMap<String, GraphQLType> modifyTypes(
    BiMap<String, GraphQLType> mapping,
    ImmutableListMultimap<String, TypeModification> modifications) {
  BiMap<String, GraphQLType> result = HashBiMap.create(mapping.size());
  for (String key : mapping.keySet()) {
    if (mapping.get(key) instanceof GraphQLObjectType) {
      GraphQLObjectType val = (GraphQLObjectType) mapping.get(key);
      if (modifications.containsKey(key)) {
        for (TypeModification modification : modifications.get(key)) {
          val = modification.apply(val);
        }
      }
      result.put(key, val);
    } else {
      result.put(key, mapping.get(key));
    }
  }
  return result;
}
项目:googles-monorepo-demo    文件:AbstractBiMapTester.java   
@Override
protected void expectMissing(Entry<K, V>... entries) {
  super.expectMissing(entries);
  for (Entry<K, V> entry : entries) {
    Entry<V, K> reversed = reverseEntry(entry);
    BiMap<V, K> inv = getMap().inverse();
    assertFalse(
        "Inverse should not contain entry " + reversed, inv.entrySet().contains(reversed));
    assertFalse(
        "Inverse should not contain key " + reversed.getKey(),
        inv.containsKey(reversed.getKey()));
    assertFalse(
        "Inverse should not contain value " + reversed.getValue(),
        inv.containsValue(reversed.getValue()));
    /*
     * TODO(cpovirk): This is a bit stronger than super.expectMissing(), which permits a <key,
     * someOtherValue> pair.
     */
    assertNull(
        "Inverse should not return a mapping for key " + reversed.getKey(),
        inv.get(reversed.getKey()));
  }
}
项目:CustomWorldGen    文件:SoundManager.java   
public SoundManager(SoundHandler p_i45119_1_, GameSettings p_i45119_2_)
{
    this.invPlayingSounds = ((BiMap)this.playingSounds).inverse();
    this.categorySounds = HashMultimap.<SoundCategory, String>create();
    this.tickableSounds = Lists.<ITickableSound>newArrayList();
    this.delayedSounds = Maps.<ISound, Integer>newHashMap();
    this.playingSoundsStopTime = Maps.<String, Integer>newHashMap();
    this.listeners = Lists.<ISoundEventListener>newArrayList();
    this.pausedChannels = Lists.<String>newArrayList();
    this.sndHandler = p_i45119_1_;
    this.options = p_i45119_2_;

    try
    {
        SoundSystemConfig.addLibrary(LibraryLWJGLOpenAL.class);
        SoundSystemConfig.setCodec("ogg", CodecJOrbis.class);
        net.minecraftforge.common.MinecraftForge.EVENT_BUS.post(new net.minecraftforge.client.event.sound.SoundSetupEvent(this));
    }
    catch (SoundSystemException soundsystemexception)
    {
        LOGGER.error(LOG_MARKER, (String)"Error linking with the LibraryJavaSound plug-in", (Throwable)soundsystemexception);
    }
}
项目:train-simulator    文件:JourneyHelper.java   
public BiMap<Train, Train> getTrainsFollowingEachOther() {
  if (false && trailingTrains.size() + 1 == world.getTrains().size()) {
    return trailingTrains;
  }
  trailingTrains.clear();

  Map<Journey, Journey> journeyTrail = getJourneysFollowingEachOther();
  journeyTrail.forEach((key, value) -> trailingTrains.put(key.getTrain(), value.getTrain()));

  return trailingTrains;
}
项目:SubgraphIsomorphismIndex    文件:IsoMatcherJena.java   
@Override
public Iterable<BiMap<V, V>> match(BiMap<V, V> baseIso, G viewGraph, G insertGraph) {
    ProblemNeighborhoodAware<BiMap<V, V>, V> problem = toProblem(baseIso, viewGraph, insertGraph);
    Iterable<BiMap<V, V>> result = () -> problem.generateSolutions().iterator();

    return result;
}
项目:CustomWorldGen    文件:GameData.java   
void registerSubstitutionAlias(String name, GameRegistry.Type type, Object toReplace) throws ExistingSubstitutionException
{
    ResourceLocation nameToSubstitute = new ResourceLocation(name);
    final BiMap<Block, Item> blockItemMap = getBlockItemMap();
    if (type == GameRegistry.Type.BLOCK)
    {
        iBlockRegistry.addSubstitutionAlias(Loader.instance().activeModContainer().getModId(), nameToSubstitute, (Block)toReplace);
        iBlockRegistry.activateSubstitution(nameToSubstitute);
    }
    else if (type == GameRegistry.Type.ITEM)
    {
        iItemRegistry.addSubstitutionAlias(Loader.instance().activeModContainer().getModId(), nameToSubstitute, (Item)toReplace);
        iItemRegistry.activateSubstitution(nameToSubstitute);
    }
}
项目:Equella    文件:WorkflowNode.java   
public static BiMap<String, Integer> getTypeMap()
{
    BiMap<String, Integer> typeMap = HashBiMap.create();
    typeMap.put(ITEM_NODE_TYPE, ITEM_TYPE);
    typeMap.put(PARALLEL_NODE_TYPE, PARALLEL_TYPE);
    typeMap.put(SERIAL_NODE_TYPE, SERIAL_TYPE);
    typeMap.put(DECISION_NODE_TYPE, DECISION_TYPE);
    return typeMap;
}
项目:powsybl-core    文件:StringToIntMapper.java   
public synchronized void dump(Writer writer) throws IOException {
    for (Map.Entry<S, BiMap<String, Integer>> entry : id2num.entrySet()) {
        S subset = entry.getKey();
        for (Map.Entry<String, Integer> entry1 : entry.getValue().entrySet()) {
            String id = entry1.getKey();
            Integer num = entry1.getValue();
            writer.write(subset + ";" + id + ";" + num + System.lineSeparator());
        }
    }
}
项目:SubgraphIsomorphismIndex    文件:IsoMatcherJena.java   
public ProblemNeighborhoodAware<BiMap<V, V>, V> toProblem(BiMap<V, V> baseIso, G viewGraph, G insertGraph) {
    ProblemNeighborhoodAware<BiMap<V, V>, V> result = new ProblemNodeMappingGraph<V, E, G, V>(
            baseIso, viewGraph, insertGraph,
            createVertexComparator, createEdgeComparator);

    //Stream<BiMap<V, V>> result = tmp.generateSolutions();

    return result;
}
项目:googles-monorepo-demo    文件:DerivedGoogleCollectionGenerators.java   
@SuppressWarnings("unchecked")
@Override
public BiMap<V, K> create(Object... elements) {
  Entry<?, ?>[] entries = new Entry<?, ?>[elements.length];
  for (int i = 0; i < elements.length; i++) {
    entries[i] = reverse((Entry<K, V>) elements[i]);
  }
  return generator.create((Object[]) entries).inverse();
}
项目:googles-monorepo-demo    文件:BiMapClearTester.java   
@MapFeature.Require(SUPPORTS_REMOVE)
public void testClearClearsInverse() {
  BiMap<V, K> inv = getMap().inverse();
  getMap().clear();
  assertTrue(getMap().isEmpty());
  assertTrue(inv.isEmpty());
}
项目:hadoop-oss    文件:ShellBasedIdMapping.java   
synchronized private void loadFullGroupMap() throws IOException {
  BiMap<Integer, String> gMap = HashBiMap.create();

  if (OS.startsWith("Mac")) {
    updateMapInternal(gMap, "group", MAC_GET_ALL_GROUPS_CMD, "\\s+",
        staticMapping.gidMapping);
  } else {
    updateMapInternal(gMap, "group", GET_ALL_GROUPS_CMD, ":",
        staticMapping.gidMapping);
  }
  gidNameMap = gMap;
  lastUpdateTime = Time.monotonicNow();
}
项目:librec-to-movies    文件:RecommendMgr.java   
public void initData(SparseMatrix dataMatrix) throws LibrecException {
    Table<Integer, Integer, Double> dataTable = dataMatrix.getDataTable();
    BiMap<String, Integer> userIds = dataModel.getUserMappingData();
    BiMap<String, Integer> itemIds = dataModel.getItemMappingData();
    SparseMatrix dateTimeDataSet = (SparseMatrix) dataModel.getDatetimeDataSet();
    Table<Integer, Integer, Double> dateTimeTable = dateTimeDataSet.getDataTable();
    for (Map.Entry<String, Integer> userId : userIds.entrySet()) {
        for (Map.Entry<String, Integer> itemId : itemIds.entrySet()) {
            Object scValue = dataTable.get(userId.getValue(), itemId.getValue());
            Object dtValue = dateTimeTable.get(userId.getValue(), itemId.getValue());
            if (scValue != null && dtValue != null) {
                Long user_id = Long.parseLong(userId.getKey());
                Long movie_id = Long.parseLong(itemId.getKey());
                Double score = (Double)scValue;
                Double datetime = (Double)dtValue;
                Rating rating = new Rating(user_id, movie_id, score);
                User user = User.findUser(user_id);
                if (user == null) continue;
                MovieEx movie = (MovieEx) MovieEx.findMovie(movie_id);
                if (movie == null) continue;
                try {
                    user.addMovie(movie, score, datetime);
                    movie.addUser(user, score, datetime);
                } catch (Exception e) {
                    // TODO: handle exception
                    e.printStackTrace();
                    throw new LibrecException("load rating set error");
                }
                //rating.save();
                Rating.allRatings.add(rating);
            }
        }
    }
}
项目:googles-monorepo-demo    文件:BiMapClearTester.java   
@MapFeature.Require(SUPPORTS_REMOVE)
public void testClearInverseKeySetClears() {
  BiMap<V, K> inv = getMap().inverse();
  inv.keySet().clear();
  assertTrue(getMap().isEmpty());
  assertTrue(inv.isEmpty());
}
项目:CustomWorldGen    文件:GameData.java   
@Override
public void onAdd(Item item, int blockId, Map<ResourceLocation, ?> slaves)
{
    if (item instanceof ItemBlock)
    {
        ItemBlock itemBlock = (ItemBlock)item;
        @SuppressWarnings("unchecked") BiMap<Block, Item> blockToItem = (BiMap<Block, Item>)slaves.get(BLOCK_TO_ITEM);
        final Block block = itemBlock.getBlock().delegate.get();
        blockToItem.forcePut(block, item);
    }
}
项目:googles-monorepo-demo    文件:BiMapClearTester.java   
@MapFeature.Require(SUPPORTS_REMOVE)
public void testKeySetClearClearsInverse() {
  BiMap<V, K> inv = getMap().inverse();
  getMap().keySet().clear();
  assertTrue(getMap().isEmpty());
  assertTrue(inv.isEmpty());
}
项目:oryx2    文件:CategoricalValueEncodings.java   
private static <T> BiMap<T,Integer> mapDistinctValues(Collection<T> distinct) {
  BiMap<T,Integer> mapping = HashBiMap.create(distinct.size());
  int encoding = 0;
  for (T t : distinct) {
    mapping.put(t, encoding);
    encoding++;
  }
  return mapping;
}
项目:neto    文件:ProtocolUnificationHandler.java   
private ProtocolUnificationHandler(boolean isUnificationMode, BiMap<Integer, Class<? extends NetoJsonMessage>> opcodeMap, SslContext sslCtx, boolean detectSsl, int maxFrameLength, String charset) {
    this.isUnificationMode = isUnificationMode;
    this.opcodeMap = opcodeMap;
    this.sslCtx = sslCtx;
    this.detectSsl = detectSsl;
    this.maxFrameLength = maxFrameLength;
    this.charset = charset;
}
项目:hashsdn-controller    文件:YangStoreSnapshot.java   
@Override
public String fromYang(final String enumClass, final String enumYangValue) {
    Preconditions.checkState(this.bindingContextProvider != null, "Binding context provider was not set yet");
    final BiMap<String, String> enumMapping = this.bindingContextProvider.getEnumMapping(enumClass);
    final String javaName = enumMapping.get(enumYangValue);
    return Preconditions.checkNotNull(javaName,
            "Unable to resolve enum value %s for enum class %s with assumed enum mapping: %s", enumYangValue,
            enumClass, enumMapping);
}
项目:rejoiner    文件:ProtoRegistry.java   
ProtoRegistry build() {
  ImmutableListMultimap<String, TypeModification> modificationsMap =
      ImmutableListMultimap.copyOf(
          this.typeModifications
              .stream()
              .map(
                  modification ->
                      new SimpleImmutableEntry<>(modification.getTypeName(), modification))
              .collect(Collectors.toList()));

  final BiMap<String, GraphQLType> mapping = HashBiMap.create();

  GraphQLInterfaceType nodeInterface =
      new Relay()
          .nodeInterface(
              env -> {
                Relay.ResolvedGlobalId resolvedGlobalId =
                    new Relay().fromGlobalId(env.getArguments().get("id").toString());
                return (GraphQLObjectType) mapping.get(resolvedGlobalId.getType());
              });

  mapping.putAll(
      modifyTypes(
          getMap(fileDescriptors, descriptors, enumDescriptors, nodeInterface),
          modificationsMap));

  return new ProtoRegistry(mapping, nodeInterface);
}
项目:rejoiner    文件:ProtoRegistry.java   
private static BiMap<String, GraphQLType> getMap(
    List<FileDescriptor> fileDescriptors,
    List<Descriptor> descriptors,
    List<EnumDescriptor> enumDescriptors,
    GraphQLInterfaceType nodeInterface) {
  HashBiMap<String, GraphQLType> mapping = HashBiMap.create(getEnumMap(enumDescriptors));
  LinkedList<Descriptor> loop = new LinkedList<>(descriptors);

  Set<FileDescriptor> fileDescriptorSet = extractDependencies(fileDescriptors);

  for (FileDescriptor fileDescriptor : fileDescriptorSet) {
    loop.addAll(fileDescriptor.getMessageTypes());
    mapping.putAll(getEnumMap(fileDescriptor.getEnumTypes()));
  }

  while (!loop.isEmpty()) {
    Descriptor descriptor = loop.pop();
    if (!mapping.containsKey(descriptor.getFullName())) {
      mapping.put(
          ProtoToGql.getReferenceName(descriptor),
          ProtoToGql.convert(descriptor, nodeInterface));
      GqlInputConverter inputConverter =
          GqlInputConverter.newBuilder().add(descriptor.getFile()).build();
      mapping.put(
          GqlInputConverter.getReferenceName(descriptor),
          inputConverter.getInputType(descriptor));
      loop.addAll(descriptor.getNestedTypes());

      mapping.putAll(getEnumMap(descriptor.getEnumTypes()));
    }
  }
  return ImmutableBiMap.copyOf(mapping);
}
项目:enigma-vk    文件:MappingsConverter.java   
private static Signature translate(Signature signature, final BiMap<ClassEntry,ClassEntry> map) {
    if (signature == null) {
        return null;
    }
    return new Signature(signature, new ClassNameReplacer() {
        @Override
        public String replace(String inClassName) {
            ClassEntry outClassEntry = map.get(new ClassEntry(inClassName));
            if (outClassEntry == null) {
                return null;
            }
            return outClassEntry.getName();
        }
    });
}
项目:TextHIN    文件:FileUtils.java   
public static BiMap<String, Integer> loadString2IntegerBiMap(String file, String delimiter) throws IOException {

    BiMap<String, Integer> res = HashBiMap.create();
    BufferedReader reader = IOUtils.getBufferedFileReader(file);
    String line;
    while ((line = reader.readLine()) != null) {

      String[] tokens = line.split(delimiter);
      res.put(tokens[0], Integer.parseInt(tokens[1]));

    }
    reader.close();
    return res;
  }
项目:SubgraphIsomorphismIndex    文件:ProblemNodeMappingGraph.java   
public ProblemNodeMappingGraph(
        BiMap<V, V> baseSolution,
        G viewGraph,
        G queryGraph,
        Function<BiMap<V, V>, Comparator<V>> nodeComparatorFactory,
        Function<BiMap<V, V>, Comparator<E>> edgeComparatorFactory)
{
    this(
        baseSolution, viewGraph, queryGraph,
        nodeComparatorFactory, edgeComparatorFactory,
        true);
}
项目:SubgraphIsomorphismIndex    文件:SubgraphIsomorphismIndexImpl.java   
/**
     * Lookup only pref keys / this skips results isomorphic to the given keys
     * @param queryGraph
     * @param exactMatch
     * @return
     */
    public Multimap<K, BiMap<V, V>> lookupFlat(G queryGraph, boolean exactMatch) {

        Set<T> queryGraphTags = extractGraphTagsWrapper(queryGraph);


        Collection<InsertPosition<K, G, V, T>> positions = new LinkedList<>();

        findInsertPositions(positions, rootNode, queryGraph, queryGraphTags, HashBiMap.create(), HashBiMap.create(), true, exactMatch); //, writer);

        Multimap<K, BiMap<V, V>> result = HashMultimap.create();

        if(logger.isDebugEnabled()) {
            logger.debug("Lookup result candidates: " + positions.size());
        }

        for(InsertPosition<K, G, V, T> pos : positions) {
            // Match with the children

            result.put(pos.getNode().getKey(), pos.getIso());
            //System.out.println("Node " + pos.node + " with keys " + pos.node.getKeys() + " iso: " + pos.getGraphIso().getInToOut());
//            for(K key : pos.node.getKeys()) {
//                result.put(key, pos.getIso());
//            }
        }
        return result;
    }
项目:googles-monorepo-demo    文件:DerivedGoogleCollectionGenerators.java   
public BiMapValueSetGenerator(
    OneSizeTestContainerGenerator<BiMap<K, V>, Entry<K, V>> mapGenerator) {
  this.mapGenerator = mapGenerator;
  final SampleElements<Map.Entry<K, V>> mapSamples = this.mapGenerator.samples();
  this.samples =
      new SampleElements<V>(
          mapSamples.e0().getValue(),
          mapSamples.e1().getValue(),
          mapSamples.e2().getValue(),
          mapSamples.e3().getValue(),
          mapSamples.e4().getValue());
}
项目:guava-mock    文件:BiMapClearTester.java   
@MapFeature.Require(SUPPORTS_REMOVE)
public void testValuesClearClearsInverse() {
  BiMap<V, K> inv = getMap().inverse();
  getMap().values().clear();
  assertTrue(getMap().isEmpty());
  assertTrue(inv.isEmpty());
}
项目:guava-mock    文件:BiMapClearTester.java   
@MapFeature.Require(SUPPORTS_REMOVE)
public void testClearInverseKeySetClears() {
  BiMap<V, K> inv = getMap().inverse();
  inv.keySet().clear();
  assertTrue(getMap().isEmpty());
  assertTrue(inv.isEmpty());
}
项目:guava-mock    文件:BiMapClearTester.java   
@MapFeature.Require(SUPPORTS_REMOVE)
public void testClearInverseValuesClears() {
  BiMap<V, K> inv = getMap().inverse();
  inv.values().clear();
  assertTrue(getMap().isEmpty());
  assertTrue(inv.isEmpty());
}
项目:hadoop    文件:ShellBasedIdMapping.java   
synchronized private void loadFullUserMap() throws IOException {
  BiMap<Integer, String> uMap = HashBiMap.create();
  if (OS.startsWith("Mac")) {
    updateMapInternal(uMap, "user", MAC_GET_ALL_USERS_CMD, "\\s+",
        staticMapping.uidMapping);
  } else {
    updateMapInternal(uMap, "user", GET_ALL_USERS_CMD, ":",
        staticMapping.uidMapping);
  }
  uidNameMap = uMap;
  lastUpdateTime = Time.monotonicNow();
}
项目:googles-monorepo-demo    文件:BiMapInverseTester.java   
BiMapPair(BiMap<K, V> original) {
  this.forward = original;
  this.backward = original.inverse();
}
项目:train-simulator    文件:GlobalMap.java   
public BiMap<Integer, JourneyPath> getJourneyPaths() {
  return journeyPathsMap;
}