微信公众号搜"智元新知"关注
微信扫一扫可直接关注哦!

com.google.common.collect.Table的实例源码

项目:synthea_java    文件Fhirstu3.java   
private static Table<String,String,String> loadSHRMapping() {
  if (!USE_SHR_EXTENSIONS) {
    // don't bother creating the table unless we need it
    return null;
  }
  Table<String,String> mappingTable = HashBasedTable.create();

  List<LinkedHashMap<String,String>> csvData;
  try {
    csvData = SimpleCSV.parse(Utilities.readResource("shr_mapping.csv"));
  } catch (IOException e) {
    e.printstacktrace();
    return null;
  }

  for (LinkedHashMap<String,String> line : csvData) {
    String system = line.get("SYstem");
    String code = line.get("CODE");
    String url = line.get("URL");

    mappingTable.put(system,code,url);
  }

  return mappingTable;
}
项目:powsybl-core    文件MathUtil.java   
public static Table<String,Float> parseMatrix(Reader reader) throws IOException {
    Table<String,Float> table = HashBasedTable.create();
    try (ICsvListReader csvReader = new CsvListReader(reader,CsvPreference.STANDARD_PREFERENCE)) {
        List<String> columnHeaders = csvReader.read();
        List<String> row;
        while ((row = csvReader.read()) != null) {
            String rowHeader = row.get(0);
            for (int i = 1; i < row.size(); i++) {
                String columnHeader = columnHeaders.get(i);
                String value = row.get(i);
                table.put(rowHeader,columnHeader,value == null ? Float.NaN : Float.parseFloat(value));
            }
        }
    }
    return table;
}
项目:configx    文件ConfigRestService.java   
/**
 * 根据Profile分组,同名配置,根据Profile的优先级覆盖
 *
 * @param configItemList
 * @param profileIdList
 * @return
 */
private List<BuildConfigItem> groupByProfile(List<BuildConfigItem> configItemList,List<Integer> profileIdList) {
    List<BuildConfigItem> filteredConfigItemList = new ArrayList<>();

    Table<String,Integer,List<BuildConfigItem>> configItemTable = getConfigItemTable(configItemList);

    for (String itemName : configItemTable.rowKeySet()) {
        for (int profileId : profileIdList) {
            List<BuildConfigItem> itemList = configItemTable.get(itemName,profileId);
            if (itemList != null && !itemList.isEmpty()) {
                filteredConfigItemList.addAll(itemList);
                break;
            }
        }
    }

    return filteredConfigItemList;
}
项目:configx    文件ConfigRestService.java   
/**
 * 将配置项构造成一个二维表,[配置名称,Profile ID,配置项]
 *
 * @param configItemList
 * @return
 */
private Table<String,List<BuildConfigItem>> getConfigItemTable(List<BuildConfigItem> configItemList) {
    Table<String,List<BuildConfigItem>> configItemTable = HashBasedTable.create();

    List<BuildConfigItem> listByNameAndProfile = null;
    for (BuildConfigItem configItem : configItemList) {
        listByNameAndProfile = configItemTable.get(configItem.getConfigName(),configItem.getProfileId());
        if (listByNameAndProfile == null) {
            listByNameAndProfile = new ArrayList<>();
            configItemTable.put(configItem.getConfigName(),configItem.getProfileId(),listByNameAndProfile);
        }
        listByNameAndProfile.add(configItem);
    }

    return configItemTable;
}
项目:Decompiledminecraft    文件BlockState.java   
public void buildPropertyValueTable(Map<Map<IProperty,Comparable>,BlockState.StateImplementation> map)
{
    if (this.propertyValueTable != null)
    {
        throw new IllegalStateException();
    }
    else
    {
        Table<IProperty,Comparable,IBlockState> table = HashBasedTable.<IProperty,IBlockState>create();

        for (IProperty <? extends Comparable > iproperty : this.properties.keySet())
        {
            for (Comparable comparable : iproperty.getAllowedValues())
            {
                if (comparable != this.properties.get(iproperty))
                {
                    table.put(iproperty,comparable,map.get(this.getPropertiesWithValue(iproperty,comparable)));
                }
            }
        }

        this.propertyValueTable = ImmutableTable.<IProperty,IBlockState>copyOf(table);
    }
}
项目:IPPR2016    文件ProcessEngineFeignServiceImpl.java   
@Override
public void storeExternalCommunicatorMessage(final ExternalCommunicatorMessage message) {
  final String[] split = message.getTransferId().split("-");
  final Long piID = Long.valueOf(split[PI_ID_INDEX]);
  final Long mfId = Long.valueOf(split[MF_ID_INDEX]);
  final Long sId = Long.valueOf(split[S_ID_INDEX]);

  final ProcessInstance processInstance = processInstanceRepository.findOne(piID);
  final MessageFlow messageFlow = Optional.ofNullable(messageFlowRepository.findOne(mfId))
      .orElseThrow(() -> new IllegalArgumentException(
          "Could not find message flow for MF_ID [" + mfId + "]"));

  final Set<BusinessObjectInstance> businessObjectInstances =
      getBusinessObjectInstances(processInstance,messageFlow.getBusinessObjectModels());

  final Table<String,BusinessObjectField> records =
      convertToMap(message.getBusinessObjects());

  businessObjectInstances.stream()
      .forEachOrdered(objectInstance -> storeValues(records,objectInstance));

  final Subject subject = subjectRepository.findOne(sId);
  subject.getSubjectState().setToReceived(messageFlow);
  subjectRepository.save((SubjectImpl) subject);
}
项目:flume-release-1.7.0    文件TestTaildirEventReader.java   
private ReliableTaildirEventReader getReader(Map<String,String> filePaths,Table<String,String> headerTable,boolean addByteOffset) {
  ReliableTaildirEventReader reader;
  try {
    reader = new ReliableTaildirEventReader.Builder()
        .filePaths(filePaths)
        .headerTable(headerTable)
        .positionFilePath(posFilePath)
        .skipToEnd(false)
        .addByteOffset(addByteOffset)
        .build();
    reader.updateTailFiles();
  } catch (IOException ioe) {
    throw Throwables.propagate(ioe);
  }
  return reader;
}
项目:BaseClient    文件BlockState.java   
public void buildPropertyValueTable(Map<Map<IProperty,IBlockState>copyOf(table);
    }
}
项目:MicroServiceProject    文件SparseTensor.java   
/**
 * retrieve a rating matrix from the tensor. Warning: it assumes there is at most one entry for each (user,item)
 * pair.
 *
 * @return a sparse rating matrix
 */
public SparseMatrix rateMatrix() {

    Table<Integer,Double> dataTable = HashBasedTable.create();
    Multimap<Integer,Integer> colMap = HashMultimap.create();

    for (TensorEntry te : this) {
        int u = te.key(userDimension);
        int i = te.key(itemDimension);

        dataTable.put(u,i,te.get());
        colMap.put(i,u);
    }

    return new SparseMatrix(dimensions[userDimension],dimensions[itemDimension],dataTable,colMap);
}
项目:argument-reasoning-comprehension-task    文件Step2dExportReasonSpanAnnotationPilot.java   
public static Table<String,String> assignmentsToTable(
        SortedMap<String,SortedSet<SingleWorkerAssignment<Step2bGoldReasonAnnotator.SentenceLabel>>> assignments)
{
    TreeBasedTable<String,String> result = TreeBasedTable.create();

    assignments.forEach((unitID,singleWorkerAssignments) -> {
        singleWorkerAssignments.forEach(sentenceLabelSingleWorkerAssignment -> {
            String workerID = sentenceLabelSingleWorkerAssignment.getWorkerID();
            String label = sentenceLabelSingleWorkerAssignment.getLabel().toString();

            // update the table
            result.put(unitID,workerID,label);
        });
    });

    return result;
}
项目:url-classifier    文件MediaTypeClassifierBuilder.java   
MediaTypeClassifierImpl(Iterable<? extends MediaType> mts) {
  Table<String,Set<MediaType>> typeTable =
      HashBasedTable.<String,Set<MediaType>>create();
  for (MediaType mt : mts) {
    String type = mt.type();
    String subtype = mt.subtype();
    Set<MediaType> typeSet = typeTable.get(type,subtype);
    if (typeSet == null) {
      typeSet = Sets.newLinkedHashSet();
      typeTable.put(type,subtype,typeSet);
    }
    typeSet.add(mt);
  }

  ImmutableTable.Builder<String,ImmutableSet<MediaType>> b =
      ImmutableTable.builder();
  for (Table.Cell<String,Set<MediaType>> cell
       : typeTable.cellSet()) {
    b.put(cell.getRowKey(),cell.getColumnKey(),ImmutableSet.copyOf(cell.getValue()));
  }
  this.types = b.build();
}
项目:uavstack    文件ReliableTaildirEventReader.java   
/**
 * Create a ReliableTaildirEventReader to watch the given directory. map<serverid.appid.logid,logpath>
 */
private ReliableTaildirEventReader(Map<String,LogPatternInfo> filePaths,String positionFilePath,boolean skipToEnd,boolean addByteOffset,String os) throws IOException {
    // Sanity checks
    Preconditions.checkNotNull(filePaths);
    Preconditions.checkNotNull(positionFilePath);
    // get operation system info
    if (logger.isDebugEnable()) {
        logger.debug(this,"Initializing {" + ReliableTaildirEventReader.class.getSimpleName()
                + "} with directory={" + filePaths + "}");
    }

    // tailFile
    this.tailFileTable = CacheBuilder.newBuilder().expireAfterWrite(2,TimeUnit.DAYS)
            .<String,LogPatternInfo> build();
    this.headerTable = headerTable;
    this.addByteOffset = addByteOffset;
    this.os = os;
    updatelog(filePaths);
    updateTailFiles(skipToEnd);

    logger.info(this,"tailFileTable: " + tailFileTable.toString());
    logger.info(this,"headerTable: " + headerTable.toString());
    logger.info(this,"Updating position from position file: " + positionFilePath);
    loadPositionFile(positionFilePath);
}
项目:uavstack    文件ReliableTaildirEventReader.java   
/**
 * Create a ReliableTaildirEventReader to watch the given directory. map<serverid.appid.logid,CollectTask> tasks,boolean addByteOffset) throws IOException {
    Map<String,LogPatternInfo> filePaths = getFilePaths(tasks);

    // Sanity checks
    Preconditions.checkNotNull(filePaths);
    // get operation system info
    if (log.isDebugEnable()) {
        log.debug(this,"Initializing {" + ReliableTaildirEventReader.class.getSimpleName() + "} with directory={"
                + filePaths + "}");
    }

    // tailFile
    this.tailFileTable = CacheBuilder.newBuilder().expireAfterWrite(2,LogPatternInfo> build();
    this.headerTable = headerTable;
    this.addByteOffset = addByteOffset;
    this.os = JVMToolHelper.isWindows() ? OS_WINDOWS : null;

    updatelog(filePaths);
    updateTailFiles(skipToEnd);

    log.info(this,"tailFileTable: " + tailFileTable.toString());
    log.info(this,"headerTable: " + headerTable.toString());
}
项目:CustomWorldGen    文件BlockStateContainer.java   
public void buildPropertyValueTable(Map < Map < IProperty<?>,Comparable<? >>,BlockStateContainer.StateImplementation > map)
{
    if (this.propertyValueTable != null)
    {
        throw new IllegalStateException();
    }
    else
    {
        Table < IProperty<?>,Comparable<?>,IBlockState > table = HashBasedTable. < IProperty<?>,IBlockState > create();

        for (Entry < IProperty<?>,Comparable<? >> entry : this.properties.entrySet())
        {
            IProperty<?> iproperty = (IProperty)entry.getKey();

            for (Comparable<?> comparable : iproperty.getAllowedValues())
            {
                if (comparable != entry.getValue())
                {
                    table.put(iproperty,comparable)));
                }
            }
        }

        this.propertyValueTable = ImmutableTable. < IProperty<?>,IBlockState > copyOf(table);
    }
}
项目:mynlp    文件CSRSparseMatrix.java   
public static void main(String[] args) {
    TreeBasedTable<Integer,Integer> table = TreeBasedTable.create();

    table.put(2,6);
    table.put(3,2,4);
    table.put(0,5);
    table.put(0,3,2);
    table.put(4,1,4,9);


    CSRSparseMatrix csr = new CSRSparseMatrix(table,5);

    for (Table.Cell<Integer,Integer> cell : table.cellSet()) {
        if (csr.get(cell.getRowKey(),cell.getColumnKey()) == cell.getValue()) {
            System.out.println(String.format("%d->%d = %d",cell.getRowKey(),cell.getValue()));
        } else {
            System.out.println("ERROR");
        }
    }


}
项目:AwesomeJavaLibraryExamples    文件ExampleTable.java   
public static void main(String[] args)
{
   Table<String,String> table = TreeBasedTable.create();

   table.put("Row1","Column1","Data1");
   table.put("Row1","Column2","Data2");

   table.put("Row2","Data3");
   table.put("Row2","Data4");

   table.put("Row3","Data5");
   table.put("Row3","Data6");
   table.put("Row3","Column3","Data7");

   Joiner.MapJoiner mapJoiner = Joiner.on(',').withkeyvalueSeparator("="); //Let's a Guava Joiner to illustrate that

   table.rowKeySet().forEach(r -> {
      System.out.println(r + "->" + mapJoiner.join(table.row(r)));
   });
}
项目:asglogic    文件ComplexGateTableSynthesis.java   
@Override
protected void fillTable(int num,String[] inputs,Table<EspressoTerm,Espressovalue> table) {
    for(State state : stategraph.getStates()) {
        BitSet x = state.getBinaryRepresentationnormalised(stategraph.getAllSignals());
        EspressoTerm t = new EspressoTerm(BitSetHelper.formatBitset(x,num),inputs);
        for(Signal sig : stategraph.getAllSignals()) {
            if(sig.getType() == SignalType.output || sig.getType() == SignalType.internal) {
                switch(state.getStateValues().get(sig)) {
                    case high:
                    case rising:
                        table.put(t,sig.getName(),Espressovalue.one);
                        break;
                    case falling:
                    case low:
                        table.put(t,Espressovalue.zero);
                        break;
                }
            }
        }
    }
}
项目:asglogic    文件TableSynthesis.java   
protected EspressoTable createEspressoTable() {
    int num = stategraph.getAllSignals().size();
    if(resetname != null) {
        num++;
    }
    int i = 0;
    String[] inputs = new String[num];
    if(resetname != null) {
        inputs[i++] = resetname;
    }
    for(Signal sig : stategraph.getAllSignals()) {
        inputs[i++] = sig.getName();
    }
    Table<EspressoTerm,Espressovalue> table = HashBasedTable.create();

    fillTable(num,inputs,table);

    return new EspressoTable(inputs,table);
}
项目:factions-top    文件ChunkLoader.java   
private Table<Integer,Material,Integer> loadChunkMaterial() throws sqlException {
    Table<Integer,Integer> target = HashBasedTable.create();
    ResultSet resultSet = selectChunkMaterial.executeQuery();

    while (resultSet.next()) {
        int id = resultSet.getInt("id");
        int chunkId = resultSet.getInt("chunk_id");
        int materialId = resultSet.getInt("material_id");
        int count = resultSet.getInt("count");

        identityCache.setChunkMaterialId(chunkId,materialId,id);
        identityCache.getMaterial(materialId).ifPresent(material ->
                target.put(chunkId,material,count));
    }

    resultSet.close();
    return target;
}
项目:factions-top    文件ChunkLoader.java   
private Table<Integer,WorthType,Double> loadChunkWorth() throws sqlException {
    Table<Integer,Double> target = HashBasedTable.create();
    ResultSet resultSet = selectChunkWorth.executeQuery();

    while (resultSet.next()) {
        int id = resultSet.getInt("id");
        int chunkId = resultSet.getInt("chunk_id");
        int worthId = resultSet.getInt("worth_id");
        double worth = resultSet.getDouble("worth");

        identityCache.setChunkWorthId(chunkId,worthId,id);
        identityCache.getWorthType(worthId).ifPresent(worthType ->
                target.put(chunkId,worthType,worth));
    }

    resultSet.close();
    return target;
}
项目:fiat    文件RedisPermissionsRepository.java   
private Table<String,ResourceType,Response<Map<String,String>>> getAllFromredis(Set<String> userIds) {
  if (userIds.size() == 0) {
    return HashBasedTable.create();
  }
  try (Jedis jedis = jedisSource.getJedis()) {
    Table<String,String>>> responseTable =
        ArrayTable.create(userIds,new ArrayIterator<>(ResourceType.values()));

    Pipeline p = jedis.pipelined();
    for (String userId : userIds) {
      for (ResourceType r : ResourceType.values()) {
        responseTable.put(userId,r,p.hgetAll(userKey(userId,r)));
      }
    }
    p.sync();
    return responseTable;
  } catch (Exception e) {
    log.error("Storage exception reading all entries.",e);
  }
  return null;
}
项目:twill    文件YarntwillRunnerService.java   
/**
 * Renews the {@link SecureStore} for all the running applications.
 *
 * @param liveApps set of running applications that need to have secure store renewal
 * @param renewer the {@link SecureStoreRenewer} for renewal
 * @param mergeCredentials {@code true} to merge with existing credentials
 * @return a {@link Multimap} containing the application runs that were Failed to have secure store renewed
 */
private Multimap<String,RunId> renewSecureStore(Table<String,RunId,YarntwillController> liveApps,SecureStoreRenewer renewer,boolean mergeCredentials) {
  Multimap<String,RunId> failureRenews = HashMultimap.create();

  // Renew the secure store for each running application
  for (Table.Cell<String,YarntwillController> liveApp : liveApps.cellSet()) {
    String application = liveApp.getRowKey();
    RunId runId = liveApp.getColumnKey();
    YarntwillController controller = liveApp.getValue();

    try {
      renewer.renew(application,runId,new YarnSecureStoreWriter(application,controller,mergeCredentials));
    } catch (Exception e) {
      LOG.warn("Failed to renew secure store for {}:{}",application,e);
      failureRenews.put(application,runId);
    }
  }

  return failureRenews;
}
项目:excel2javabeans    文件RowObjectCreator.java   
public RowObjectCreator(BeanInstantiator<T> instantiator,List<ExcelBeanField> beanFields,boolean cellDataMapAttachable,Sheet sheet,Table<Integer,ImageData> imageDataTable,DataFormatter cellFormatter,int rowNum) {
    this.beanFields = beanFields;
    this.cellDataMapAttachable = cellDataMapAttachable;

    if (cellDataMapAttachable) cellDataMap = Maps.newHashMap();
    else cellDataMap = null;

    this.sheet = sheet;
    this.imageDataTable = imageDataTable;
    this.cellFormatter = cellFormatter;
    this.row = sheet.getRow(rowNum);
    this.object = this.row == null ? null : (T) instantiator.newInstance();
}
项目:excel2javabeans    文件ExcelImages.java   
private static Table<Integer,ImageData> readAllCellImages(XSSfdrawing drawing,Sheet sheet) {
    val images = HashBasedTable.<Integer,ImageData>create();
    for (val shape : drawing.getShapes()) {
        if (!(shape instanceof XSSFPicture)) continue;

        val picture = (XSSFPicture) shape;
        val imageData = createImageData(picture.getPictureData());

        val axisRow = computeAxisRowIndex(sheet,picture);
        val axisCol = computeAxisColIndex(sheet,picture);

        images.put(axisRow,axisCol,imageData);
    }

    return images;
}
项目:cachecloud    文件RedisCenterImpl.java   
private AppStats getAppStats(long appId,long collectTime,Table<RedisConstant,Long> table,Map<RedisConstant,Map<String,Object>> infoMap) {
    AppStats appStats = new AppStats();
    appStats.setAppId(appId);
    appStats.setCollectTime(collectTime);
    appStats.setModifyTime(new Date());
    appStats.setUsedMemory(MapUtils.getLong(infoMap.get(RedisConstant.Memory),RedisInfoEnum.used_memory.getValue(),0L));
    appStats.setHits(MapUtils.getLong(table.row(RedisConstant.Stats),RedisInfoEnum.keyspace_hits.getValue(),0L));
    appStats.setMisses(MapUtils.getLong(table.row(RedisConstant.Stats),RedisInfoEnum.keyspace_misses.getValue(),0L));
    appStats.setevictedKeys(MapUtils.getLong(table.row(RedisConstant.Stats),RedisInfoEnum.evicted_keys.getValue(),0L));
    appStats.setExpiredKeys(MapUtils.getLong(table.row(RedisConstant.Stats),RedisInfoEnum.expired_keys.getValue(),0L));
    appStats.setNetInputByte(MapUtils.getLong(table.row(RedisConstant.Stats),RedisInfoEnum.total_net_input_bytes.getValue(),0L));
    appStats.setNetoutputByte(MapUtils.getLong(table.row(RedisConstant.Stats),RedisInfoEnum.total_net_output_bytes.getValue(),0L));
    appStats.setConnectedClients(MapUtils.getIntValue(infoMap.get(RedisConstant.Clients),RedisInfoEnum.connected_clients.getValue(),0));
    appStats.setobjectsize(getobjectsize(infoMap));
    return appStats;
}
项目:cachecloud    文件RedisCenterImpl.java   
private List<AppCommandStats> getCommandStatsList(long appId,Long> table) {
    Map<String,Long> commandMap = table.row(RedisConstant.Commandstats);
    List<AppCommandStats> list = new ArrayList<AppCommandStats>();
    if (commandMap == null) {
        return list;
    }
    for (String key : commandMap.keySet()) {
        String commandName = key.replace("cmdstat_","");
        long callCount = MapUtils.getLong(commandMap,key,0L);
        if (callCount == 0L) {
            continue;
        }
        AppCommandStats commandStats = new AppCommandStats();
        commandStats.setAppId(appId);
        commandStats.setCollectTime(collectTime);
        commandStats.setCommandName(commandName);
        commandStats.setCommandCount(callCount);
        commandStats.setModifyTime(new Date());
        list.add(commandStats);
    }
    return list;
}
项目:hybris-connector    文件SetAttributeValidator.java   
@Override
protected boolean hasValidValueId(final FhAttributeData attribute,final List<Violation> violations)
{
    final Table<Optional<String>,Optional<Locale>,String> values = attribute.getValues();
    for (final Optional<String> optional : values.rowKeySet())
    {
        final String key = optional == null || !optional.isPresent() ? "_absent_" : optional.get();
        if (!key.matches(VALUE_ID_PATTERN))
        {
            rejectValue(attribute,violations,"The \"set\" attribute valueId key \"" + key + "\" does not match the appropriate pattern.");
            return false;
        }
    }
    return true;
}
项目:hybris-connector    文件SetAttributeValidator.java   
@Override
protected void validateValue(final FhAttributeData attribute,final List<com.fredhopper.core.connector.index.report.Violation> violations)
{
    final Table<Optional<String>,String> values = attribute.getValues();
    for (final Optional<String> valueId : values.rowKeySet())
    {
        final Map<Optional<Locale>,String> valueMap = values.row(valueId);
        if (CollectionUtils.isEmpty(valueMap) || valueMap.containsKey(Optional.empty()) || valueMap.containsKey(null))
        {
            rejectValue(attribute,"The \"set\" attribute Locale key must be set.");
            return;
        }
        if (valueMap.containsValue(null) || valueMap.containsValue(""))
        {
            rejectValue(attribute,"The \"set\" attribute value must not be blank.");
            return;
        }
    }
}
项目:hybris-connector    文件TextAttributeValidator.java   
@Override
protected void validateValue(final FhAttributeData attribute,String> values = attribute.getValues();
    final Map<Optional<Locale>,String> valueMap = values.row(Optional.empty());
    if (CollectionUtils.isEmpty(valueMap) || valueMap.entrySet().size() != 1 || !valueMap.containsKey(Optional.empty()))
    {
        rejectValue(attribute,"The \"text\" attribute value cannot be localized.");
        return;
    }

    final String value = valueMap.get(Optional.empty());
    if (StringUtils.isBlank(value))
    {
        rejectValue(attribute,"The \"text\" attribute value must not be blank.");
    }
}
项目:hybris-connector    文件List64AttributeValidator.java   
@Override
protected boolean isValidSize(final FhAttributeData attribute,String> values = attribute.getValues();
    if (values.isEmpty())
    {
        rejectValue(attribute,"The \"list64\" attribute \"" + attribute.getAttributeId() + "\" has no values assigned.");
        return false;
    }
    if (values.rowKeySet().size() > MAX_SIZE)
    {
        rejectValue(attribute,"The \"list64\" attribute \"" + attribute.getAttributeId() + "\" values total must not exceed 64.");
        return false;
    }
    return true;
}
项目:hybris-connector    文件Set64AttributeValidator.java   
@Override
protected boolean isValidSize(final FhAttributeData attribute,"The \"set64\" attribute \"" + attribute.getAttributeId() + "\" has no values assigned.");
        return false;
    }
    if (values.rowKeySet().size() > MAX_SIZE)
    {
        rejectValue(attribute,"The \"set64\" attribute \"" + attribute.getAttributeId() + "\" values total must not exceed 64.");
        return false;
    }
    return true;
}
项目:hybris-connector    文件AssetAttributeValidator.java   
@Override
protected void validateValue(final FhAttributeData attribute,String> valueMap = values.row(Optional.empty());
    if (CollectionUtils.isEmpty(valueMap) || valueMap.containsKey(Optional.empty()) || valueMap.containsKey(null))
    {
        rejectValue(attribute,"The \"asset\" value's Locale key must be set.");
        return;
    }
    for (final Entry<Optional<Locale>,String> entry : valueMap.entrySet())
    {
        if (StringUtils.isBlank(entry.getValue()))
        {
            rejectValue(attribute,"The \"asset\" value must not be blank.");
        }
    }
}
项目:hybris-connector    文件IntAttributeValidator.java   
@Override
protected void validateValue(final FhAttributeData attribute,"The \"int\" attribute value cannot be localized.");
        return;
    }

    final String value = valueMap.get(Optional.empty());
    try
    {
        if (StringUtils.isBlank(value)
                || !(Integer.parseInt(value) > 0 && Double.valueOf(Integer.MAX_VALUE).compareto(Double.valueOf(value)) > 0))
        {
            rejectValue(attribute,"The \"int\" attribute value is not in the supported value range.");
        }
    }
    catch (final NumberFormatException ex)
    {
        rejectValue(attribute,"The \"int\" attribute value does not have the appropriate format.");
    }
}
项目:JAADAS    文件InfoflowSolver.java   
@Override
public Set<Pair<Unit,Abstraction>> endSummary(SootMethod m,Abstraction d3) {
    Set<Pair<Unit,Abstraction>> res = null;

    for (Unit sP : icfg.getStartPointsOf(m)) {
        Set<Table.Cell<Unit,Abstraction,EdgeFunction<IFDSSolver.BinaryDomain>>> endSum =
                super.endSummary(sP,d3);
        if (endSum == null || endSum.isEmpty())
            continue;
        if (res == null)
            res = new HashSet<>();

        for (Table.Cell<Unit,EdgeFunction<IFDSSolver.BinaryDomain>> cell : endSum)
            res.add(new Pair<>(cell.getRowKey(),cell.getColumnKey()));
    }
    return res;
}
项目:ALEA    文件SpliceJunctionHelper.java   
/**
 * Combine junctions from both strands.  Used for Sashimi plot.
 * Note: Flanking depth arrays are not combined.
 */
private List<SpliceJunctionFeature> combinestrandJunctionsMaps() {

    // Start with all + junctions
    Table<Integer,SpliceJunctionFeature> combinedStartEndJunctionsMap = HashBasedTable.create(posstartEndJunctionsMap);

    // Merge in - junctions
    for (Table.Cell<Integer,SpliceJunctionFeature> negJunctionCell : negStartEndJunctionsMap.cellSet()) {

        int junctionStart = negJunctionCell.getRowKey();
        int junctionEnd = negJunctionCell.getColumnKey();
        SpliceJunctionFeature negFeat = negJunctionCell.getValue();

        SpliceJunctionFeature junction = combinedStartEndJunctionsMap.get(junctionStart,junctionEnd);

        if (junction == null) {
            // No existing (+) junction here,just add the (-) one\
            combinedStartEndJunctionsMap.put(junctionStart,junctionEnd,negFeat);
        } else {
            int newJunctionDepth = junction.getJunctionDepth() + negFeat.getJunctionDepth();
            junction.setJunctionDepth(newJunctionDepth);
        }
    }

    return new ArrayList<SpliceJunctionFeature>(combinedStartEndJunctionsMap.values());
}
项目:XPathBuilder    文件IXPath.java   
static String getXPath(Table<ACTIONS,LinkedList<ATTRIBUTES>,LinkedList<XPathValues>> xPathTable) {
    String xPath = "";
    for (Table.Cell<ACTIONS,LinkedList<XPathValues>> tableCell : xPathTable.cellSet()) {

        if (tableCell.getColumnKey() == null)
            Assert.assertTrue("attributesList is null",false);

        if (tableCell.getValue() == null)
            Assert.assertTrue("listofListValues is null",false);

        for (ATTRIBUTES attribute : tableCell.getColumnKey()) {

            for (XPathValues values : tableCell.getValue()) {
                xPath = xPath + XPathBuilder.getXPath(tableCell.getRowKey(),attribute,values);
            }
        }
    }
    return xPath;
}
项目:famf    文件SparseMatrix.java   
/**
 * Construct a sparse matrix with CRS structures (CCS structure optional).
 * 
 * @deprecated I don't recommend to use this method as it (takes time and)
 *             is better to constructe the column structure at the time when
 *             you construct the row structure (of data table). This method
 *             is put here (as an example) to show how to construct column
 *             structure according to the data table.
 */
public SparseMatrix(int rows,int cols,Float> dataTable,boolean isCCSUsed) {
    numRows = rows;
    numColumns = cols;

    Multimap<Integer,Integer> colMap = null;

    if (isCCSUsed) {
        colMap = HashMultimap.create();
        for (Cell<Integer,Float> cell : dataTable.cellSet())
            colMap.put(cell.getColumnKey(),cell.getRowKey());
    }

    construct(dataTable,colMap);
}
项目:synthea_java    文件Concepts.java   
/**
 * Catalog all concepts from the given module into the given Table.
 * 
 * @param concepts Table of concepts to add to
 * @param module Module to parse for concepts and codes
 */
public static void inventoryModule(Table<String,String> concepts,JsonObject module) {
  JsonObject states = module.get("states").getAsJsonObject();
  for (Entry<String,JsonElement> entry : states.entrySet()) {
    JsonObject state = entry.getValue().getAsJsonObject();
    inventoryState(concepts,state);
  }
}

版权声明:本文内容由互联网用户自发贡献,该文观点与技术仅代表作者本人。本站仅提供信息存储空间服务,不拥有所有权,不承担相关法律责任。如发现本站有涉嫌侵权/违法违规的内容, 请发送邮件至 [email protected] 举报,一经查实,本站将立刻删除。