java.util.HashSet#add ( )源码实例Demo

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

源代码1 项目: es6draft   文件: IteratorOperations.java
@Override
protected String findNext() {
    HashSet<String> visitedKeys = this.visitedKeys;
    ExecutionContext cx = this.cx;
    for (ScriptObject obj = this.obj; obj != null;) {
        for (Iterator<String> keys = this.keys; keys.hasNext();) {
            String key = keys.next();
            ScriptObject.Enumerability e = obj.isEnumerableOwnProperty(cx, key);
            if (e != ScriptObject.Enumerability.Deleted) {
                if (visitedKeys.add(key) && e == ScriptObject.Enumerability.Enumerable) {
                    return key;
                }
            }
        }
        this.obj = obj = obj.getPrototypeOf(cx);
        if (obj != null) {
            this.keys = obj.ownEnumerablePropertyKeys(cx);
        } else {
            this.keys = null;
        }
    }
    return null;
}
 
源代码2 项目: LibScout   文件: ApkUtils.java
public static Set<ZipEntry> getClassesDex(File apkFile) throws ZipException, IOException {
	HashSet<ZipEntry> result = new HashSet<ZipEntry>();
	ZipFile f = new ZipFile(apkFile);
	
    final Enumeration<? extends ZipEntry> entries = f.entries();
    while (entries.hasMoreElements()) {
        final ZipEntry entry = entries.nextElement();
        if (entry.getName().matches("classes[1-9]{0,1}\\.dex"))
        	result.add(entry);
    }
    
    // TODO: unzip those entries to tmp dir and return set<Files>

    f.close();
    return result;
}
 
源代码3 项目: accumulo-examples   文件: Index.java
public static void index(int numPartitions, Text docId, String doc, String splitRegex,
    BatchWriter bw) throws Exception {

  String[] tokens = doc.split(splitRegex);

  Text partition = genPartition(doc.hashCode() % numPartitions);

  Mutation m = new Mutation(partition);

  HashSet<String> tokensSeen = new HashSet<>();

  for (String token : tokens) {
    token = token.toLowerCase();

    if (!tokensSeen.contains(token)) {
      tokensSeen.add(token);
      m.put(new Text(token), docId, new Value(new byte[0]));
    }
  }

  if (m.size() > 0)
    bw.addMutation(m);
}
 
源代码4 项目: rf2-to-json-conversion   文件: EsRunner.java
public static void main(String[] args) throws Exception {
    TransformerConfig config = new TransformerConfig();
    config.setDatabaseName("es-edition");
    config.setDefaultTermDescriptionType("900000000000003001");
    config.setDefaultTermLangCode("es");
    config.setDefaultTermLanguageRefset("900000000000509007");
    config.setEditionName("Spanish Edition");
    config.setEffectiveTime("20140430");
    config.setExpirationTime("20141231");
    config.setNormalizeTextIndex(true);
    HashSet<String> baselineFolders = new HashSet<String>();
    baselineFolders.add("/Users/alo/Downloads/Releases/SnomedCT_Release_INT_20140131/RF2Release/Snapshot");
    config.setFoldersBaselineLoad(baselineFolders);
    config.setModulesToIgnoreBaselineLoad(new ArrayList<String>());
    HashSet<String> extensionFolders = new HashSet<String>();
    extensionFolders.add("/Users/alo/Downloads/Releases/SnomedCT_Release-es_INT_20140430/RF2Release/Snapshot");
    config.setFoldersExtensionLoad(extensionFolders);
    ArrayList<String> modulesToIgnore = new ArrayList<String>();
    config.setModulesToIgnoreExtensionLoad(modulesToIgnore);

    config.setOutputFolder("/Users/alo/Downloads/Releases/es-json");

    TransformerDiskBased tr = new TransformerDiskBased();

    tr.convert(config);
}
 
源代码5 项目: hop   文件: Const.java
/**
 * Sorts the array of Strings, determines the uniquely occurring strings.
 *
 * @param strings the array that you want to do a distinct on
 * @return a sorted array of uniquely occurring strings
 */
public static String[] getDistinctStrings( String[] strings ) {
  if ( strings == null ) {
    return null;
  }
  if ( strings.length == 0 ) {
    return new String[] {};
  }
  HashSet<String> set = new HashSet<>();
  for (String string : strings) {
    set.add(string);
  }
  List<String> list = new ArrayList<>( set );
  Collections.sort(list);
  return list.toArray( new String[0] );
}
 
源代码6 项目: gemfirexd-oss   文件: IdUtil.java
/**
  Return an IdList with all the ids that in l1 and l2
  or null if not ids are on both lists.

  @param l1 An array of ids in normal form
  @param l2 An array of ids in nomral form
  */
public static String intersect(String[] l1, String[] l2)
{
	if (l1 == null || l2 == null) return null;
	HashSet h = new HashSet();
	for(int ix=0;ix<l2.length;ix++) h.add(l2[ix]); 
	Vector v = new Vector();
	for(int ix=0;ix<l1.length;ix++) if (h.contains(l1[ix])) v.addElement(l1[ix]);
	return vectorToIdList(v,true); 
}
 
源代码7 项目: openjdk-jdk8u   文件: FcFontConfiguration.java
@Override
public String[] getPlatformFontNames() {
    HashSet<String> nameSet = new HashSet<String>();
    FcFontManager fm = (FcFontManager) fontManager;
    FontConfigManager fcm = fm.getFontConfigManager();
    FcCompFont[] fcCompFonts = fcm.loadFontConfig();
    for (int i=0; i<fcCompFonts.length; i++) {
        for (int j=0; j<fcCompFonts[i].allFonts.length; j++) {
            nameSet.add(fcCompFonts[i].allFonts[j].fontFile);
        }
    }
    return nameSet.toArray(new String[0]);
}
 
源代码8 项目: unitime   文件: ExamGridForm.java
public Vector<ComboBoxLookup> getEndTimes(String examType) {
    Vector<ComboBoxLookup> ret = new Vector<ComboBoxLookup>();
    HashSet added = new HashSet();
    for (Iterator i=iPeriods.get(examType).iterator();i.hasNext();) {
        ExamPeriod period = (ExamPeriod)i.next();
        if (added.add(period.getEndSlot())) {
            ret.addElement(new ComboBoxLookup(period.getEndTimeLabel(), String.valueOf(period.getEndSlot())));
        }
    }
    return ret;
}
 
源代码9 项目: presto   文件: EquatableValueSet.java
static EquatableValueSet of(Type type, Object first, Object... rest)
{
    HashSet<ValueEntry> set = new LinkedHashSet<>(rest.length + 1);
    set.add(ValueEntry.create(type, first));
    for (Object value : rest) {
        set.add(ValueEntry.create(type, value));
    }
    return new EquatableValueSet(type, true, set);
}
 
源代码10 项目: flink   文件: Kafka08Fetcher.java
/**
 * Returns a list of unique topics from for the given partitions.
 *
 * @param partitions A the partitions
 * @return A list of unique topics
 */
private static List<String> getTopics(List<KafkaTopicPartitionState<TopicAndPartition>> partitions) {
	HashSet<String> uniqueTopics = new HashSet<>();
	for (KafkaTopicPartitionState<TopicAndPartition> fp: partitions) {
		uniqueTopics.add(fp.getTopic());
	}
	return new ArrayList<>(uniqueTopics);
}
 
源代码11 项目: moleculer-java   文件: UidGeneratorTest.java
protected void testGenerator(UidGenerator gen) throws Exception {
	gen.started(new ServiceBroker());
	HashSet<String> set = new HashSet<>();
	for (int i = 0; i < 500; i++) {
		set.add(gen.nextUID());
	}
	assertEquals(500, set.size());
}
 
源代码12 项目: hibersap   文件: ReflectionUtil.java
public static Set<Field> getHibersapSessionFields(final Object target) {
    HashSet<Field> fields = new HashSet<>();

    Field[] declaredFields = target.getClass().getDeclaredFields();
    for (Field declaredField : declaredFields) {
        if (declaredField.getAnnotation(HibersapSession.class) != null) {
            fields.add(declaredField);
        }
    }

    return fields;
}
 
源代码13 项目: StatSVN   文件: SvnLogfileParser.java
private void createImplicitAction(final HashSet implicitActions, final String child, final FileBuilder childBuilder, final RevisionData parentData,
        final int k) {
    // we want to memorize this implicit action.
    final RevisionData implicit = parentData.createCopy();
    implicitActions.add(implicit);

    // avoid concurrent modification errors.
    final List toMove = new ArrayList();
    for (final Iterator it = childBuilder.getRevisions().subList(k, childBuilder.getRevisions().size()).iterator(); it.hasNext();) {
        final RevisionData revToMove = (RevisionData) it.next();
        // if
        // (!revToMove.getRevisionNumber().equals(implicit.getRevisionNumber()))
        // {
        toMove.add(revToMove);
        // }
    }

    // remove the revisions to be moved.
    childBuilder.getRevisions().removeAll(toMove);

    // don't call addRevision directly. buildRevision
    // does more.
    builder.buildFile(child, false, false, new HashMap(), new HashMap());

    // only add the implicit if the last one for the
    // file is NOT a deletion!
    // if (!toMove.isEmpty() && !((RevisionData)
    // toMove.get(0)).isDeletion()) {
    builder.buildRevision(implicit);
    // }

    // copy back the revisions we removed.
    for (final Iterator it = toMove.iterator(); it.hasNext();) {
        builder.buildRevision((RevisionData) it.next());
    }
}
 
源代码14 项目: scava   文件: SearchRepoAuthorCounter.java
private int count(String repoLocation) {	
	System.out.println("count ( " + repoLocation + " )");
	HashSet<String> repoAuthorsSet = new HashSet<String>();
	
	try {
		Repository repo = new FileRepository(new File(repoLocation + "/.git").getCanonicalPath());
		
		// get a list of all known heads, tags, remotes, ...
           Collection<Ref> allRefs = repo.getAllRefs().values();

           // a RevWalk allows to walk over commits based on some filtering that is defined
           try (RevWalk revWalk = new RevWalk( repo )) {
               for( Ref ref : allRefs ) {
                   revWalk.markStart( revWalk.parseCommit( ref.getObjectId() ));
               }
               System.out.println("Walking all commits starting with " + allRefs.size() + " refs: " + allRefs);
               for( RevCommit commit : revWalk ) {
               	repoAuthorsSet.add(commit.getAuthorIdent().getEmailAddress());
               }
           }
	
	} catch (IOException e) {
		System.err.println("\n" + "[" + workflow.getName() + "] " + "Failed to count repository authors. Wrong cloned repository location?");
		e.printStackTrace();
	}	 
	
	return repoAuthorsSet.size();
}
 
源代码15 项目: JAADAS   文件: VarAccess.java
/**
 * @ast method 
 * @aspect InnerClasses
 * @declaredat /Users/eric/Documents/workspaces/clara-soot/JastAddJ/Java1.4Backend/InnerClasses.jrag:162
 */
public void collectEnclosingVariables(HashSet set, TypeDecl typeDecl) {
  Variable v = decl();
  if(!v.isInstanceVariable() && !v.isClassVariable() && v.hostType() == typeDecl)
    set.add(v);
  super.collectEnclosingVariables(set, typeDecl);
}
 
源代码16 项目: pravega   文件: OperationProcessorTests.java
/**
 * Tests the ability of the OperationProcessor to process Operations when encountering invalid operations (such as
 * appends to StreamSegments that do not exist or to those that are sealed). This covers the following exceptions:
 * * StreamSegmentNotExistsException
 * * StreamSegmentSealedException
 * * General MetadataUpdateException.
 */
@Test
public void testWithInvalidOperations() throws Exception {
    int streamSegmentCount = 10;
    int appendsPerStreamSegment = 40;
    long sealedStreamSegmentId = 6; // We are going to prematurely seal this StreamSegment.
    long deletedStreamSegmentId = 8; // We are going to prematurely mark this StreamSegment as deleted.
    long nonExistentStreamSegmentId; // This is a bogus StreamSegment, that does not exist.

    @Cleanup
    TestContext context = new TestContext();

    // Generate some test data (no need to complicate ourselves with Transactions here; that is tested in the no-failure test).
    HashSet<Long> streamSegmentIds = createStreamSegmentsInMetadata(streamSegmentCount, context.metadata);
    nonExistentStreamSegmentId = streamSegmentIds.size();
    streamSegmentIds.add(nonExistentStreamSegmentId);
    context.metadata.getStreamSegmentMetadata(sealedStreamSegmentId).markSealed();
    context.metadata.getStreamSegmentMetadata(deletedStreamSegmentId).markDeleted();
    List<Operation> operations = generateOperations(streamSegmentIds, new HashMap<>(), appendsPerStreamSegment,
            METADATA_CHECKPOINT_EVERY, false, false);

    // Setup an OperationProcessor and start it.
    @Cleanup
    TestDurableDataLog dataLog = TestDurableDataLog.create(CONTAINER_ID, MAX_DATA_LOG_APPEND_SIZE, executorService());
    dataLog.initialize(TIMEOUT);
    @Cleanup
    OperationProcessor operationProcessor = new OperationProcessor(context.metadata, context.stateUpdater,
            dataLog, getNoOpCheckpointPolicy(), executorService());
    operationProcessor.startAsync().awaitRunning();

    // Process all generated operations.
    List<OperationWithCompletion> completionFutures = processOperations(operations, operationProcessor);

    // Wait for all such operations to complete. We are expecting exceptions, so verify that we do.
    AssertExtensions.assertThrows(
            "No operations failed.",
            OperationWithCompletion.allOf(completionFutures)::join,
            ex -> ex instanceof MetadataUpdateException || ex instanceof StreamSegmentException);

    HashSet<Long> streamSegmentsWithNoContents = new HashSet<>();
    streamSegmentsWithNoContents.add(sealedStreamSegmentId);
    streamSegmentsWithNoContents.add(deletedStreamSegmentId);
    streamSegmentsWithNoContents.add(nonExistentStreamSegmentId);

    // Verify that the "right" operations failed, while the others succeeded.
    for (OperationWithCompletion oc : completionFutures) {
        if (oc.operation instanceof StorageOperation) {
            long streamSegmentId = ((StorageOperation) oc.operation).getStreamSegmentId();
            if (streamSegmentsWithNoContents.contains(streamSegmentId)) {
                Assert.assertTrue("Completion future for invalid StreamSegment " + streamSegmentId + " did not complete exceptionally.",
                        oc.completion.isCompletedExceptionally());
                Predicate<Throwable> errorValidator;
                if (streamSegmentId == sealedStreamSegmentId) {
                    errorValidator = ex -> ex instanceof StreamSegmentSealedException;
                } else if (streamSegmentId == deletedStreamSegmentId) {
                    errorValidator = ex -> ex instanceof StreamSegmentNotExistsException;
                } else {
                    errorValidator = ex -> ex instanceof MetadataUpdateException;
                }

                AssertExtensions.assertThrows("Unexpected exception for failed Operation.", oc.completion::join, errorValidator);
                continue;
            }
        }

        // If we get here, we must verify no exception was thrown.
        oc.completion.join();
    }

    performLogOperationChecks(completionFutures, context.memoryLog, dataLog, context.metadata);
    performMetadataChecks(streamSegmentIds, streamSegmentsWithNoContents, new HashMap<>(), completionFutures, context.metadata, false, false);
    performReadIndexChecks(completionFutures, context.readIndex);
    operationProcessor.stopAsync().awaitTerminated();
}
 
源代码17 项目: anno4j   文件: TimeStateTest.java
@Test
public void testSourceDates() throws RepositoryException, IllegalAccessException, InstantiationException {
    TimeState state = this.anno4j.createObject(TimeState.class);

    TimeState result = this.anno4j.findByID(TimeState.class, state.getResourceAsString());

    assertEquals(0, result.getSourceDates().size());

    state.addSourceDate("2015-01-28T12:00:00Z");

    result = this.anno4j.findByID(TimeState.class, state.getResourceAsString());

    assertEquals(1, result.getSourceDates().size());

    HashSet<String> sourceDates = new HashSet<>();
    sourceDates.add("2015-01-28T12:00:00Z");
    sourceDates.add("2016-01-28T12:00:00Z");

    state.setSourceDates(sourceDates);

    result = this.anno4j.findByID(TimeState.class, state.getResourceAsString());

    assertEquals(2, result.getSourceDates().size());
}
 
源代码18 项目: walkmod-core   文件: RemoveProvidersYMLAction.java
@Override
public void doAction(JsonNode node) throws Exception {
	HashSet<String> providerSet = new HashSet<String>();
	for (String elem : providers) {
		String[] partsType = elem.split(":");
		if (partsType.length == 1) {
			elem = "org.walkmod:walkmod-" + elem + "-plugin:" + elem;
		}
		if (partsType.length != 3 && partsType.length != 1) {
			throw new TransformerException("Invalid conf-provider");
		}
		providerSet.add(elem);
	}
	if (node.has("conf-providers")) {
		JsonNode aux = node.get("conf-providers");
		if (aux.isArray()) {
			ArrayNode providersList = (ArrayNode) node.get("conf-providers");
			Iterator<JsonNode> it = providersList.iterator();
			ArrayNode newProvidersList = new ArrayNode(provider.getObjectMapper().getNodeFactory());
			while (it.hasNext()) {
				JsonNode next = it.next();
				if (next.isObject()) {
					String type = next.get("type").asText();
					String[] parts = type.split(":");
					if (parts.length == 1) {
						type = "org.walkmod:walkmod-" + type + "-plugin:" + type;
					} else if (parts.length != 3) {
						throw new TransformerException("Invalid conf-provider");
					}
					if (!providerSet.contains(type)) {
						newProvidersList.add(next);
					}
				}
			}
			ObjectNode oNode = (ObjectNode) node;
			if (newProvidersList.size() > 0) {
				oNode.set("conf-providers", newProvidersList);
			} else {
				oNode.remove("conf-providers");
			}
			provider.write(node);
		}
	}

}
 
源代码19 项目: EasyEE   文件: Test.java
@SuppressWarnings("unused")
	public static void main(String[] args) {

		String str="#AAAA#BBBB#CCCC#DDDD#EEEE#FFFF#GGGG#HHHH#IIII#JJJJ#KKKK#LLLL#MMMM#NNNN#";
		
		HashSet<String> set=new HashSet<String>();
		set.add("AAAA");
		set.add("BBBB");
		set.add("CCCC");
		set.add("DDDD");
		set.add("EEEE");
		set.add("FFFF");
		set.add("GGGG");
		set.add("HHHH");
		set.add("IIII");
		set.add("JJJJ");
		set.add("KKKK");
		set.add("LLLL");
		set.add("MMMM");
		set.add("NNNN");
		
		long s=System.currentTimeMillis();
		for(int i=0;i<=100000;i++){
//			str.indexOf("NNNN");
			"".trim().equals("");
		}
		long e=System.currentTimeMillis();
		
		long s2=System.currentTimeMillis();
		for(int i=0;i<=100000;i++){
//			set.contains("NNNN");
			boolean f="fsffsaaaaaaaa".trim().length()>0;
		}
		long e2=System.currentTimeMillis();
		
		System.out.println("str:"+(e-s)+"ms");
		System.out.println("set:"+(e2-s2)+"ms");
		
		
		System.out.println(Arrays.toString("a,b,c".split(",")));
		System.out.println(Arrays.toString("a,b,c,".split(",")));
		System.out.println(Arrays.toString(",a,b,c,".split(",")));
		System.out.println(Arrays.toString(",a,b,c,".split("")));
		System.out.println(Arrays.toString(",a#b,c,".split(",|#")));
		System.out.println(Arrays.toString("fasfsa/a.fd".split(",|#")));
	
	}
 
源代码20 项目: JByteMod-Beta   文件: StackVarsProcessor.java
private static boolean isVersionToBeReplaced(VarVersionPair usedvar, HashMap<Integer, HashSet<VarVersionPair>> mapVars,
    SSAUConstructorSparseEx ssau, VarVersionPair leftpaar) {

  VarVersionsGraph ssuversions = ssau.getSsuversions();

  SFormsFastMapDirect mapLiveVars = ssau.getLiveVarVersionsMap(usedvar);
  if (mapLiveVars == null) {
    // dummy version, predecessor of a phi node
    return false;
  }

  // compare protected ranges
  if (!InterpreterUtil.equalObjects(ssau.getMapVersionFirstRange().get(leftpaar), ssau.getMapVersionFirstRange().get(usedvar))) {
    return false;
  }

  for (Entry<Integer, HashSet<VarVersionPair>> ent : mapVars.entrySet()) {
    FastSparseSet<Integer> liveverset = mapLiveVars.get(ent.getKey());
    if (liveverset == null) {
      return false;
    }

    HashSet<VarVersionNode> domset = new HashSet<>();
    for (VarVersionPair verpaar : ent.getValue()) {
      domset.add(ssuversions.nodes.getWithKey(verpaar));
    }

    boolean isdom = false;

    for (Integer livever : liveverset) {
      VarVersionNode node = ssuversions.nodes.getWithKey(new VarVersionPair(ent.getKey().intValue(), livever.intValue()));

      if (ssuversions.isDominatorSet(node, domset)) {
        isdom = true;
        break;
      }
    }

    if (!isdom) {
      return false;
    }
  }

  return true;
}