Example usage for com.google.common.collect ImmutableMap keySet

List of usage examples for com.google.common.collect ImmutableMap keySet

Introduction

In this page you can find the example usage for com.google.common.collect ImmutableMap keySet.

Prototype

public ImmutableSet<K> keySet() 

Source Link

Usage

From source file:com.facebook.buck.rules.modern.impl.DefaultClassInfo.java

DefaultClassInfo(Class<?> clazz, Optional<ClassInfo<? super T>> superInfo) {
    this.type = CaseFormat.UPPER_CAMEL.to(CaseFormat.LOWER_UNDERSCORE, clazz.getSimpleName()).intern();
    this.superInfo = superInfo;

    Optional<Class<?>> immutableBase = findImmutableBase(clazz);
    ImmutableList.Builder<FieldInfo<?>> fieldsBuilder = ImmutableList.builder();
    if (immutableBase.isPresent()) {
        ImmutableMap<Field, Boolean> parameterFields = parameterFieldsFromFields(clazz);
        ImmutableMap<Field, Method> parameterMethods = findMethodsForFields(parameterFields.keySet(), clazz);
        parameterFields.forEach((field, isLazy) -> {
            Method method = parameterMethods.get(field);
            if (method == null) {
                return;
            }//from   w  w  w .  ja  v a2  s .  c o  m
            AddToRuleKey addAnnotation = method.getAnnotation(AddToRuleKey.class);
            // TODO(cjhopman): Add @ExcludeFromRuleKey annotation and require that all fields are
            // either explicitly added or explicitly excluded.
            Optional<CustomFieldBehavior> customBehavior = Optional
                    .ofNullable(method.getDeclaredAnnotation(CustomFieldBehavior.class));
            if (addAnnotation != null && !addAnnotation.stringify()) {
                if (isLazy) {
                    throw new RuntimeException(
                            "@Value.Lazy fields cannot be @AddToRuleKey, change it to @Value.Derived.");
                }
                Nullable methodNullable = method.getAnnotation(Nullable.class);
                boolean methodOptional = Optional.class.isAssignableFrom(method.getReturnType());
                fieldsBuilder.add(
                        forFieldWithBehavior(field, methodNullable != null || methodOptional, customBehavior));
            } else {
                fieldsBuilder.add(excludedField(field, customBehavior));
            }
        });
    } else {
        for (final Field field : clazz.getDeclaredFields()) {
            // TODO(cjhopman): Make this a Precondition.
            if (!Modifier.isFinal(field.getModifiers())) {
                LOG.warn("All fields of a Buildable must be final (%s.%s)", clazz.getSimpleName(),
                        field.getName());
            }

            if (Modifier.isStatic(field.getModifiers())) {
                continue;
            }
            field.setAccessible(true);

            Optional<CustomFieldBehavior> customBehavior = Optional
                    .ofNullable(field.getDeclaredAnnotation(CustomFieldBehavior.class));
            AddToRuleKey addAnnotation = field.getAnnotation(AddToRuleKey.class);
            // TODO(cjhopman): Add @ExcludeFromRuleKey annotation and require that all fields are either
            // explicitly added or explicitly excluded.
            if (addAnnotation != null && !addAnnotation.stringify()) {
                fieldsBuilder.add(forFieldWithBehavior(field, field.getAnnotation(Nullable.class) != null,
                        customBehavior));
            } else {
                fieldsBuilder.add(excludedField(field, customBehavior));
            }
        }
    }

    if (clazz.isMemberClass()) {
        // TODO(cjhopman): This should also iterate over the outer class's class hierarchy.
        Class<?> outerClazz = clazz.getDeclaringClass();
        // I don't think this can happen, but if it does, this needs to be updated to handle it
        // correctly.
        Preconditions.checkArgument(
                !outerClazz.isAnonymousClass() && !outerClazz.isMemberClass() && !outerClazz.isLocalClass());
        for (final Field field : outerClazz.getDeclaredFields()) {
            field.setAccessible(true);
            if (!Modifier.isStatic(field.getModifiers())) {
                continue;
            }
            // TODO(cjhopman): Make this a Precondition.
            if (!Modifier.isFinal(field.getModifiers())) {
                LOG.warn("All static fields of a Buildable's outer class must be final (%s.%s)",
                        outerClazz.getSimpleName(), field.getName());
            }
        }
    }
    this.fields = fieldsBuilder.build();
}

From source file:io.fabric8.elasticsearch.plugin.KibanaUserReindexAction.java

private boolean containsKibanaUserIndex(ActionResponse response) {
    String index = "";

    if (response instanceof MultiGetResponse) {
        for (MultiGetItemResponse item : ((MultiGetResponse) response).getResponses()) {
            GetResponse itemResponse = item.getResponse();
            Failure itemFailure = item.getFailure();

            if (itemResponse == null) {
                if (isKibanaUserIndex(itemFailure.getIndex())) {
                    return true;
                }//ww  w.  j av a2  s  .c o  m
            } else {
                if (isKibanaUserIndex(itemResponse.getIndex())) {
                    return true;
                }
            }
        }

        return false;
    }

    if (response instanceof IndexResponse) {
        index = ((IndexResponse) response).getIndex();
    } else if (response instanceof GetResponse) {
        index = ((GetResponse) response).getIndex();
    } else if (response instanceof DeleteResponse) {
        index = ((DeleteResponse) response).getIndex();
    } else if (response instanceof GetFieldMappingsResponse) {
        ImmutableMap<String, ImmutableMap<String, ImmutableMap<String, FieldMappingMetaData>>> mappings = ((GetFieldMappingsResponse) response)
                .mappings();
        for (String key : mappings.keySet()) {
            index = key;
        }
    }

    return isKibanaUserIndex(index);
}

From source file:org.apache.bigtop.bigpetstore.datagenerator.generators.locations.ZipcodeReader.java

public ImmutableList<Location> readData() throws FileNotFoundException {
    ImmutableMap<String, Double> incomes = readIncomeData(this.zipcodeIncomesFile);
    ImmutableMap<String, Long> populations = readPopulationData(this.zipcodePopulationFile);
    ImmutableMap<String, ZipcodeLocationRecord> coordinates = readCoordinates(this.zipcodeCoordinatesFile);

    Set<String> zipcodeSubset = new HashSet<String>(incomes.keySet());
    zipcodeSubset.retainAll(populations.keySet());
    zipcodeSubset.retainAll(coordinates.keySet());

    List<Location> table = new Vector<Location>();
    for (String zipcode : zipcodeSubset) {
        Location record = new Location(zipcode, coordinates.get(zipcode).coordinates,
                coordinates.get(zipcode).city, coordinates.get(zipcode).state, incomes.get(zipcode),
                populations.get(zipcode));
        table.add(record);/*  w w w . java 2s.  c  om*/
    }

    return ImmutableList.copyOf(table);
}

From source file:com.facebook.buck.rules.modern.builders.RemoteExecutionStrategy.java

private ListenableFuture<RemoteExecutionActionInfo> uploadInputs(BuildTarget buildTarget,
        RemoteExecutionActionInfo actionInfo) throws Exception {
    Objects.requireNonNull(actionInfo);
    ImmutableMap<Digest, UploadDataSupplier> requiredData = actionInfo.getRequiredData();
    long totalInputSizeBytes = 0;
    for (Digest digest : requiredData.keySet()) {
        totalInputSizeBytes += digest.getSize();
    }/*from  ww w .j a va 2s . c o m*/
    if (maxInputSizeBytes.isPresent() && maxInputSizeBytes.getAsInt() < totalInputSizeBytes) {
        throw new RuntimeException("Max file size exceeded for Remote Execution, action contains: "
                + totalInputSizeBytes + " bytes, max allowed: " + maxInputSizeBytes.getAsInt());
    }
    Digest actionDigest = actionInfo.getActionDigest();
    Scope uploadingInputsScope = RemoteExecutionActionEvent.sendEvent(eventBus, State.UPLOADING_INPUTS,
            buildTarget, Optional.of(actionDigest));
    ListenableFuture<Void> inputsUploadedFuture = executionClients.getContentAddressedStorage()
            .addMissing(requiredData);
    return Futures.transform(inputsUploadedFuture, ignored -> {
        uploadingInputsScope.close();
        // The actionInfo may be very large, so explicitly clear out the unneeded parts.
        // actionInfo.getRequiredData() in particular may be very, very large and is unneeded once
        // uploading has completed.
        return actionInfo.withRequiredData(ImmutableMap.of());
    }, MoreExecutors.directExecutor());
}

From source file:org.apache.bigtop.bigpetstore.datagenerator.datareaders.ZipcodeReader.java

public ImmutableList<ZipcodeRecord> readData() throws FileNotFoundException {
    ImmutableMap<String, Double> incomes = readIncomeData(this.zipcodeIncomesFile);
    ImmutableMap<String, Long> populations = readPopulationData(this.zipcodePopulationFile);
    ImmutableMap<String, ZipcodeLocationRecord> coordinates = readCoordinates(this.zipcodeCoordinatesFile);

    Set<String> zipcodeSubset = new HashSet<String>(incomes.keySet());
    zipcodeSubset.retainAll(populations.keySet());
    zipcodeSubset.retainAll(coordinates.keySet());

    List<ZipcodeRecord> table = new Vector<ZipcodeRecord>();
    for (String zipcode : zipcodeSubset) {
        ZipcodeRecord record = new ZipcodeRecord(zipcode, coordinates.get(zipcode).coordinates,
                coordinates.get(zipcode).city, coordinates.get(zipcode).state, incomes.get(zipcode),
                populations.get(zipcode));
        table.add(record);//from   www.jav a  2 s.  c  o  m
    }

    return ImmutableList.copyOf(table);
}

From source file:com.facebook.buck.command.config.AbstractConfigIgnoredByDaemon.java

@Value.Lazy
public ImmutableMap<String, ImmutableMap<String, String>> getRawConfigForParser() {
    ImmutableMap<String, ImmutableSet<String>> ignoredFields = getIgnoreFieldsForDaemonRestart();
    ImmutableMap<String, ImmutableMap<String, String>> rawSections = getDelegate().getConfig()
            .getSectionToEntries();//  w w  w .j  av a  2  s .c  o  m

    // If the raw config doesn't have sections which have ignored fields, then just return it as-is.
    ImmutableSet<String> sectionsWithIgnoredFields = ignoredFields.keySet();
    if (Sets.intersection(rawSections.keySet(), sectionsWithIgnoredFields).isEmpty()) {
        return rawSections;
    }

    // Otherwise, iterate through the config to do finer-grain filtering.
    ImmutableMap.Builder<String, ImmutableMap<String, String>> filtered = ImmutableMap.builder();
    for (Map.Entry<String, ImmutableMap<String, String>> sectionEnt : rawSections.entrySet()) {
        String sectionName = sectionEnt.getKey();

        // If this section doesn't have a corresponding ignored section, then just add it as-is.
        if (!sectionsWithIgnoredFields.contains(sectionName)) {
            filtered.put(sectionEnt);
            continue;
        }

        // If none of this section's entries are ignored, then add it as-is.
        ImmutableMap<String, String> fields = sectionEnt.getValue();
        ImmutableSet<String> ignoredFieldNames = ignoredFields.getOrDefault(sectionName, ImmutableSet.of());
        if (Sets.intersection(fields.keySet(), ignoredFieldNames).isEmpty()) {
            filtered.put(sectionEnt);
            continue;
        }

        // Otherwise, filter out the ignored fields.
        ImmutableMap<String, String> remainingKeys = ImmutableMap
                .copyOf(Maps.filterKeys(fields, Predicates.not(ignoredFieldNames::contains)));
        filtered.put(sectionName, remainingKeys);
    }

    return MoreMaps.filterValues(filtered.build(), Predicates.not(Map::isEmpty));
}

From source file:com.kibana.multitenancy.plugin.KibanaUserReindexAction.java

private boolean containsKibanaUserIndex(ActionResponse response) {
    String index = "";

    if (response instanceof MultiGetResponse) {
        for (MultiGetItemResponse item : ((MultiGetResponse) response).getResponses()) {
            GetResponse itemResponse = item.getResponse();
            Failure itemFailure = item.getFailure();

            if (itemResponse == null) {
                if (isKibanaUserIndex(itemFailure.getIndex()))
                    return true;
            } else {
                if (isKibanaUserIndex(itemResponse.getIndex()))
                    return true;
            }//from  ww w .  j a v a 2s .  c  om
        }

        return false;
    }

    if (response instanceof IndexResponse)
        index = ((IndexResponse) response).getIndex();
    else if (response instanceof GetResponse)
        index = ((GetResponse) response).getIndex();
    else if (response instanceof DeleteResponse)
        index = ((DeleteResponse) response).getIndex();
    else if (response instanceof GetFieldMappingsResponse) {
        ImmutableMap<String, ImmutableMap<String, ImmutableMap<String, FieldMappingMetaData>>> mappings = ((GetFieldMappingsResponse) response)
                .mappings();
        for (String key : mappings.keySet())
            index = key;
    }

    return isKibanaUserIndex(index);
}

From source file:com.google.devtools.build.lib.skyframe.GraphBackedRecursivePackageProvider.java

private void collectPackagesUnder(final RepositoryName repository, Set<TraversalInfo> traversals,
        ImmutableList.Builder<PathFragment> builder) throws InterruptedException {
    Map<TraversalInfo, SkyKey> traversalToKeyMap = Maps.asMap(traversals,
            new Function<TraversalInfo, SkyKey>() {
                @Override// w w  w .  ja v  a 2s. c  o  m
                public SkyKey apply(TraversalInfo traversalInfo) {
                    return CollectPackagesUnderDirectoryValue.key(repository, traversalInfo.rootedDir,
                            traversalInfo.excludedSubdirectories);
                }
            });
    Map<SkyKey, SkyValue> values = graph.getSuccessfulValues(traversalToKeyMap.values());

    ImmutableSet.Builder<TraversalInfo> subdirTraversalBuilder = ImmutableSet.builder();
    for (Map.Entry<TraversalInfo, SkyKey> entry : traversalToKeyMap.entrySet()) {
        TraversalInfo info = entry.getKey();
        SkyKey key = entry.getValue();
        SkyValue val = values.get(key);
        CollectPackagesUnderDirectoryValue collectPackagesValue = (CollectPackagesUnderDirectoryValue) val;
        if (collectPackagesValue != null) {
            if (collectPackagesValue.isDirectoryPackage()) {
                builder.add(info.rootedDir.getRelativePath());
            }

            ImmutableMap<RootedPath, Boolean> subdirectoryTransitivelyContainsPackages = collectPackagesValue
                    .getSubdirectoryTransitivelyContainsPackages();
            for (RootedPath subdirectory : subdirectoryTransitivelyContainsPackages.keySet()) {
                if (subdirectoryTransitivelyContainsPackages.get(subdirectory)) {
                    PathFragment subdirectoryRelativePath = subdirectory.getRelativePath();
                    ImmutableSet<PathFragment> excludedSubdirectoriesBeneathThisSubdirectory = PathFragment
                            .filterPathsStartingWith(info.excludedSubdirectories, subdirectoryRelativePath);
                    subdirTraversalBuilder.add(
                            new TraversalInfo(subdirectory, excludedSubdirectoriesBeneathThisSubdirectory));
                }
            }
        }
    }

    ImmutableSet<TraversalInfo> subdirTraversals = subdirTraversalBuilder.build();
    if (!subdirTraversals.isEmpty()) {
        collectPackagesUnder(repository, subdirTraversals, builder);
    }
}

From source file:io.divolte.server.Server.java

Server(final ValidatedConfiguration vc, final IncomingRequestListener listener) {
    host = vc.configuration().global.server.host;
    port = vc.configuration().global.server.port;

    // First thing we need to do is load all the schemas: the sinks need these, but they come from the
    // mappings.// ww  w  . ja  v a  2  s . co m
    final SchemaRegistry schemaRegistry = new SchemaRegistry(vc);

    // Build a set of referenced sinks. These are the only ones we need to instantiate.
    final ImmutableSet<String> referencedSinkNames = vc.configuration().mappings.values().stream()
            .flatMap(mc -> mc.sinks.stream()).collect(ImmutableSet.toImmutableSet());

    // Instantiate the active sinks:
    //  - As a practical matter, unreferenced sinks have no associated schema, which means they
    //    can't be initialized.
    //  - This is also where we check whether HDFS and Kafka are globally enabled/disabled.
    logger.debug("Initializing active sinks...");
    sinks = vc.configuration().sinks.entrySet().stream()
            .filter(sink -> referencedSinkNames.contains(sink.getKey()))
            .filter(sink -> vc.configuration().global.hdfs.enabled
                    || !(sink.getValue() instanceof HdfsSinkConfiguration))
            .filter(sink -> vc.configuration().global.gcs.enabled
                    || !(sink.getValue() instanceof GoogleCloudStorageSinkConfiguration))
            .filter(sink -> vc.configuration().global.kafka.enabled
                    || !(sink.getValue() instanceof KafkaSinkConfiguration))
            .collect(ImmutableMap.toImmutableMap(Map.Entry::getKey,
                    sink -> sink.getValue().getFactory().create(vc, sink.getKey(), schemaRegistry)));
    logger.info("Initialized sinks: {}", sinks.keySet());

    logger.debug("Initializing mappings...");
    incomingRequestProcessingPool = new IncomingRequestProcessingPool(vc, schemaRegistry, sinks, listener);

    logger.debug("Initializing sources...");
    // Now instantiate all the sources. We do this in parallel because instantiation can be quite slow.
    final ImmutableMap<String, HttpSource> sources = vc.configuration().sources.entrySet().parallelStream()
            .collect(ImmutableMap.toImmutableMap(Map.Entry::getKey, source -> source.getValue().createSource(vc,
                    source.getKey(), incomingRequestProcessingPool)));

    logger.debug("Attaching sources: {}", sources.keySet());
    // Once all created we can attach them to the server. This has to be done sequentially.
    PathHandler pathHandler = new PathHandler();
    for (final HttpSource source : sources.values()) {
        pathHandler = source.attachToPathHandler(pathHandler);
    }
    logger.info("Initialized sources: {}", sources.keySet());

    pathHandler.addExactPath("/ping", PingHandler::handlePingRequest);
    if (vc.configuration().global.server.serveStaticResources) {
        // Catch-all handler; must be last if present.
        // XXX: Our static resources assume the default 'browser' endpoint.
        pathHandler.addPrefixPath("/", createStaticResourceHandler());
    }
    final SetHeaderHandler headerHandler = new SetHeaderHandler(pathHandler, Headers.SERVER_STRING, "divolte");
    final HttpHandler canonicalPathHandler = new CanonicalPathHandler(headerHandler);
    final GracefulShutdownHandler rootHandler = new GracefulShutdownHandler(
            vc.configuration().global.server.useXForwardedFor
                    ? new ProxyAdjacentPeerAddressHandler(canonicalPathHandler)
                    : canonicalPathHandler);

    shutdownHandler = rootHandler;
    undertow = Undertow.builder().addHttpListener(port, host.orElse(null))
            .setHandler(vc.configuration().global.server.debugRequests ? new RequestDumpingHandler(rootHandler)
                    : rootHandler)
            .build();
}

From source file:com.google.javascript.jscomp.newtypes.NominalType.java

NominalType(ImmutableMap<String, JSType> typeMap, RawNominalType rawType) {
    Preconditions.checkState(typeMap.isEmpty() || typeMap.keySet().containsAll(rawType.getTypeParameters())
            && rawType.getTypeParameters().containsAll(typeMap.keySet()));
    this.typeMap = typeMap;
    this.rawType = rawType;
}