类org.apache.commons.lang.ArrayUtils源码实例Demo

下面列出了怎么用org.apache.commons.lang.ArrayUtils的API类实例代码及写法,或者点击链接到github查看源代码。

源代码1 项目: Liudao   文件: DimensionService.java
public List distinct(Event event, String[] condDimensions, EnumTimePeriod enumTimePeriod, String aggrDimension) {
    if (event == null || ArrayUtils.isEmpty(condDimensions) || enumTimePeriod == null || aggrDimension == null) {
        logger.error("参数错误");
        return null;
    }

    Document query = new Document();
    for (String dimension : condDimensions) {
        Object value = getProperty(event, dimension);
        if (value == null || "".equals(value)) {
            return null;
        }
        query.put(dimension, value);
    }

    query.put(Event.OPERATETIME, new Document("$gte", enumTimePeriod.getMinTime(event.getOperateTime())).append("$lte", enumTimePeriod.getMaxTime(event.getOperateTime())));
    return mongoDao.distinct(event.getScene(), query, aggrDimension);
}
 
/**
 * Checks if a CAR file is deployed.
 *
 * @param carFileName CAR file name.
 * @return True if exists, False otherwise.
 */
private Callable<Boolean> isCarFileDeployed(final String carFileName) {
    return new Callable<Boolean>() {
        @Override
        public Boolean call() throws ApplicationAdminExceptionException, RemoteException {
            log.info("waiting " + MAX_TIME + " millis for car deployment " + carFileName);
            Calendar startTime = Calendar.getInstance();
            long time = Calendar.getInstance().getTimeInMillis() - startTime.getTimeInMillis();
            String[] applicationList = applicationAdminClient.listAllApplications();
            if (applicationList != null) {
                if (ArrayUtils.contains(applicationList, carFileName)) {
                    log.info("car file deployed in " + time + " milliseconds");
                    return true;
                }
            }
            return false;
        }
    };
}
 
/**
 * Recursively go through UIPermissionNode.
 *
 * @param node UIPermissionNode of permissions.
 * @return  Permission[] of permissions.
 */
private Permission[] getAllPermissions(UIPermissionNode node) {

    List<Permission> permissions = new ArrayList<>();
    UIPermissionNode[] childNodes = node.getNodeList();
    Permission permission = new Permission();
    permission.setDisplayName(node.getDisplayName());
    permission.setResourcePath(node.getResourcePath());
    permissions.add(permission);
    if (ArrayUtils.isNotEmpty(childNodes)) {
        for (UIPermissionNode childNode : childNodes) {
            permissions.addAll(Arrays.asList(getAllPermissions(childNode)));
        }
    }
    return permissions.toArray(new Permission[0]);
}
 
/**
 * Use this method to replace original passwords with random passwords before sending to UI front-end
 * @param identityProvider
 * @return
 */
public static void removeOriginalPasswords(IdentityProvider identityProvider) {

    if (identityProvider == null || identityProvider.getProvisioningConnectorConfigs() == null) {
        return;
    }

    for (ProvisioningConnectorConfig provisioningConnectorConfig : identityProvider
            .getProvisioningConnectorConfigs()) {
        Property[] properties = provisioningConnectorConfig.getProvisioningProperties();
        if (ArrayUtils.isEmpty(properties)) {
            continue;
        }
        properties = RandomPasswordProcessor.getInstance().removeOriginalPasswords(properties);
        provisioningConnectorConfig.setProvisioningProperties(properties);
    }
}
 
/**
 * Remove random passwords with original passwords when sending password properties to Service Back-end
 *
 * @param properties
 */
public Property[] removeRandomPasswords(Property[] properties, boolean withCacheClear) {

    if (ArrayUtils.isEmpty(properties)) {
        return new Property[0];
    }

    String uuid = IdentityApplicationManagementUtil.getPropertyValue(properties,
            IdentityApplicationConstants.UNIQUE_ID_CONSTANT);
    if (StringUtils.isBlank(uuid)) {
        if (log.isDebugEnabled()) {
            log.debug("Cache Key not found for Random Password Container");
        }
    } else {
        properties = removeUniqueIdProperty(properties);
        RandomPassword[] randomPasswords = getRandomPasswordContainerFromCache(uuid, withCacheClear);
        if (!ArrayUtils.isEmpty(randomPasswords)) {
            replaceRandomPasswordsWithOriginalPasswords(properties,
                    randomPasswords);
        }
    }
    return properties;
}
 
源代码6 项目: aion-germany   文件: BonusService.java
public BonusItemGroup[] getGroupsByType(BonusType type) {
	switch (type) {
		case BOSS:
			return itemGroups.getBossGroups();
		case ENCHANT:
			return itemGroups.getEnchantGroups();
		case FOOD:
			return itemGroups.getFoodGroups();
		case GATHER:
			return (BonusItemGroup[]) ArrayUtils.addAll(itemGroups.getOreGroups(), itemGroups.getGatherGroups());
		case MANASTONE:
			return itemGroups.getManastoneGroups();
		case MEDICINE:
			return itemGroups.getMedicineGroups();
		case TASK:
			return itemGroups.getCraftGroups();
		case MOVIE:
			return null;
		default:
			log.warn("Bonus of type " + type + " is not implemented");
			return null;
	}
}
 
源代码7 项目: carbon-identity   文件: RandomPasswordProcessor.java
/**
 * Remove original passwords with random passwords when sending password properties to UI front-end
 * @param properties
 */
public Property[] removeOriginalPasswords(Property[] properties){

    if (ArrayUtils.isEmpty(properties)){
        return new Property[0];
    }

    properties = addUniqueIdProperty(properties);
    String uuid = IdentityApplicationManagementUtil
            .getPropertyValue(properties, IdentityApplicationConstants.UNIQUE_ID_CONSTANT);
    String randomPhrase = IdentityApplicationConstants.RANDOM_PHRASE_PREFIX + uuid;
    RandomPassword[] randomPasswords = replaceOriginalPasswordsWithRandomPasswords(
            randomPhrase, properties);
    if (!ArrayUtils.isEmpty(randomPasswords)) {
        addPasswordContainerToCache(randomPasswords, uuid);
    }

    return properties;
}
 
源代码8 项目: astor   文件: StrTokenizerTest.java
public void test3() {

        String input = "a;b; c;\"d;\"\"e\";f; ; ;";
        StrTokenizer tok = new StrTokenizer(input);
        tok.setDelimiterChar(';');
        tok.setQuoteChar('"');
        tok.setIgnoredMatcher(StrMatcher.noneMatcher());
        tok.setIgnoreEmptyTokens(false);
        String tokens[] = tok.getTokenArray();

        String expected[] = new String[]{"a", "b", " c", "d;\"e", "f", " ", " ", "",};

        assertEquals(ArrayUtils.toString(tokens), expected.length, tokens.length);
        for (int i = 0; i < expected.length; i++) {
            assertTrue("token[" + i + "] was '" + tokens[i] + "' but was expected to be '" + expected[i] + "'",
                    ObjectUtils.equals(expected[i], tokens[i]));
        }

    }
 
/**
 * Method to check whether given header fields present or not.
 *
 * @param data List of strings representing the header names in received request.
 * @param keys List of string represents the headers fields.
 */
public void checkMandatoryHeadersPresent(Map<String, String[]> data, String... keys) {
  if (MapUtils.isEmpty(data)) {
    throw new ProjectCommonException(
        ResponseCode.invalidRequestData.getErrorCode(),
        ResponseCode.invalidRequestData.getErrorMessage(),
        ResponseCode.CLIENT_ERROR.getResponseCode());
  }
  Arrays.stream(keys)
      .forEach(
          key -> {
            if (ArrayUtils.isEmpty(data.get(key))) {
              throw new ProjectCommonException(
                  ResponseCode.mandatoryHeadersMissing.getErrorCode(),
                  ResponseCode.mandatoryHeadersMissing.getErrorMessage(),
                  ResponseCode.CLIENT_ERROR.getResponseCode(),
                  key);
            }
          });
}
 
源代码10 项目: freehealth-connector   文件: CryptoImpl.java
private SigningCredential retrieveSigningCredential(String alias, KeyStore keyStore) {
   try {
      Certificate[] c = keyStore.getCertificateChain(alias);
      if (ArrayUtils.isEmpty(c)) {
         throw new IllegalArgumentException("The KeyStore doesn't contain the required key with alias [" + alias + "]");
      } else {
         X509Certificate[] certificateChain = (X509Certificate[])Arrays.copyOf(c, c.length, X509Certificate[].class);
         PrivateKey privateKey = (PrivateKey)keyStore.getKey(alias, (char[])null);
         return SigningCredential.create(privateKey, Iterables.newList(certificateChain));
      }
   } catch (KeyStoreException var6) {
      throw new IllegalArgumentException("Given keystore hasn't been initialized", var6);
   } catch (NoSuchAlgorithmException var7) {
      throw new IllegalStateException("There is a problem with the Security configuration... Check if all the required security providers are correctly registered", var7);
   } catch (UnrecoverableKeyException var8) {
      throw new IllegalStateException("The private key with alias [" + alias + "] could not be recovered from the given keystore", var8);
   }
}
 
源代码11 项目: govpay   文件: ConfigurazioniConverter.java
private static it.govpay.bd.configurazione.model.Mail getConfigurazioneMailPromemoriaDTO(MailTemplate mailPromemoria) throws ServiceException, ValidationException{
	it.govpay.bd.configurazione.model.Mail dto = new it.govpay.bd.configurazione.model.Mail();
	
	dto.setAllegaPdf(mailPromemoria.AllegaPdf());
	dto.setTipo(mailPromemoria.getTipo());
	if(mailPromemoria.getTipo() != null) {
		// valore tipo contabilita non valido
		if(it.govpay.backoffice.v1.beans.MailTemplate.TipoEnum.fromValue(mailPromemoria.getTipo()) == null) {
			throw new ValidationException("Codifica inesistente per tipo trasformazione. Valore fornito [" +
					mailPromemoria.getTipo() + "] valori possibili " + ArrayUtils.toString(it.govpay.backoffice.v1.beans.MailTemplate.TipoEnum.values()));
		}
	}
	
	dto.setMessaggio((ConverterUtils.toJSON(mailPromemoria.getMessaggio(),null)));
	dto.setOggetto(ConverterUtils.toJSON(mailPromemoria.getOggetto(),null));
	
	return dto;
}
 
public Result<X509Certificate[]> getCertificate(byte[] publicKeyIdentifier) throws TechnicalConnectorException {
   GetCertificateRequest request = new GetCertificateRequest();
   RaUtils.setCommonAttributes(request);
   request.setPublicKeyIdentifier(publicKeyIdentifier);
   Result<GetCertificateResponse> resp = RaUtils.invokeCertRa(ConnectorXmlUtils.toString((Object)request), "urn:be:fgov:ehealth:etee:certra:protocol:v2:getcertificate", GetCertificateResponse.class);
   if (!resp.getStatus().equals(Status.OK)) {
      return resp.getStatus().equals(Status.PENDING) ? new Result(resp.getTime()) : new Result("Unable to obtain certificate", resp.getCause());
   } else {
      X509Certificate[] x509Certificates = new X509Certificate[0];

      byte[] x509Certificate;
      for(Iterator i$ = ((GetCertificateResponse)resp.getResult()).getX509Certificates().iterator(); i$.hasNext(); x509Certificates = (X509Certificate[])((X509Certificate[])ArrayUtils.add(x509Certificates, CertificateUtils.toX509Certificate(x509Certificate)))) {
         x509Certificate = (byte[])i$.next();
      }

      return new Result(x509Certificates);
   }
}
 
public final List<String> getExceptionList(String... errorType) {
   List<String> exceptionList = new ArrayList();
   if (ArrayUtils.contains(errorType, "WARN")) {
      exceptionList.addAll(this.exceptionWarningList);
   }

   if (ArrayUtils.contains(errorType, "ERROR")) {
      exceptionList.addAll(this.exceptionErrorList);
   }

   if (ArrayUtils.contains(errorType, "FATAL")) {
      exceptionList.addAll(this.exceptionFatalList);
   }

   return exceptionList;
}
 
源代码14 项目: pentaho-kettle   文件: MultiMergeJoinMeta.java
@Override
public String getXML() {
  StringBuilder retval = new StringBuilder();

  String[] inputStepsNames  = inputSteps != null ? inputSteps : ArrayUtils.EMPTY_STRING_ARRAY;
  retval.append( "    " ).append( XMLHandler.addTagValue( "join_type", getJoinType() ) );
  for ( int i = 0; i < inputStepsNames.length; i++ ) {
    retval.append( "    " ).append( XMLHandler.addTagValue( "step" + i, inputStepsNames[ i ] ) );
  }

  retval.append( "    " ).append( XMLHandler.addTagValue( "number_input", inputStepsNames.length ) );
  retval.append( "    " ).append( XMLHandler.openTag( "keys" ) ).append( Const.CR );
  for ( int i = 0; i < keyFields.length; i++ ) {
    retval.append( "      " ).append( XMLHandler.addTagValue( "key", keyFields[i] ) );
  }
  retval.append( "    " ).append( XMLHandler.closeTag( "keys" ) ).append( Const.CR );

  return retval.toString();
}
 
源代码15 项目: sofa-acts   文件: CSVApisUtil.java
/**
 * get .csv file path based on the class
 *
 * @param objClass
 * @param csvPath
 * @return
 */
private static String getCsvFileName(Class<?> objClass, String csvPath) {

    if (isWrapClass(objClass)) {
        LOG.warn("do nothing when simple type");
        return null;
    }
    String[] paths = csvPath.split("/");
    ArrayUtils.reverse(paths);

    String className = objClass.getSimpleName() + ".csv";

    if (!StringUtils.equals(className, paths[0])) {
        csvPath = StringUtils.replace(csvPath, paths[0], className);
    }

    return csvPath;
}
 
源代码16 项目: govpay   文件: ConfigurazioniConverter.java
private static it.govpay.bd.configurazione.model.Mail getConfigurazioneMailPromemoriaDTOPatch(MailTemplate mailPromemoria) throws ServiceException, ValidationException{
		it.govpay.bd.configurazione.model.Mail dto = new it.govpay.bd.configurazione.model.Mail();
		
		dto.setAllegaPdf(mailPromemoria.AllegaPdf());
		dto.setTipo(mailPromemoria.getTipo());
		if(mailPromemoria.getTipo() != null) {
			// valore tipo contabilita non valido
			if(it.govpay.backoffice.v1.beans.MailTemplate.TipoEnum.fromValue(mailPromemoria.getTipo()) == null) {
				throw new ValidationException("Codifica inesistente per tipo trasformazione. Valore fornito [" +
						mailPromemoria.getTipo() + "] valori possibili " + ArrayUtils.toString(it.govpay.backoffice.v1.beans.MailTemplate.TipoEnum.values()));
			}
		}
		
//		if(mailPromemoria.getMessaggio() != null && mailPromemoria.getMessaggio() instanceof String)
//			dto.setMessaggio((String) mailPromemoria.getMessaggio());
//		else 
			dto.setMessaggio((ConverterUtils.toJSON(mailPromemoria.getMessaggio(),null)));
//		if(mailPromemoria.getOggetto() != null && mailPromemoria.getOggetto() instanceof String)
//			dto.setOggetto((String) mailPromemoria.getOggetto());
//		else 
			dto.setOggetto((ConverterUtils.toJSON(mailPromemoria.getOggetto(),null)));
		
		return dto;
	}
 
源代码17 项目: incubator-gobblin   文件: FileListUtils.java
private static List<FileStatus> listMostNestedPathRecursivelyHelper(FileSystem fs, List<FileStatus> files,
    FileStatus fileStatus, PathFilter fileFilter)
    throws IOException {
  if (fileStatus.isDirectory()) {
    FileStatus[] curFileStatus = fs.listStatus(fileStatus.getPath());
    if (ArrayUtils.isEmpty(curFileStatus)) {
      files.add(fileStatus);
    } else {
      for (FileStatus status : curFileStatus) {
        listMostNestedPathRecursivelyHelper(fs, files, status, fileFilter);
      }
    }
  } else if (fileFilter.accept(fileStatus.getPath())) {
    files.add(fileStatus);
  }
  return files;
}
 
源代码18 项目: astor   文件: StrTokenizerTest.java
public void test2() {

        String input = "a;b;c ;\"d;\"\"e\";f; ; ;";
        StrTokenizer tok = new StrTokenizer(input);
        tok.setDelimiterChar(';');
        tok.setQuoteChar('"');
        tok.setIgnoredMatcher(StrMatcher.noneMatcher());
        tok.setIgnoreEmptyTokens(false);
        String tokens[] = tok.getTokenArray();

        String expected[] = new String[]{"a", "b", "c ", "d;\"e", "f", " ", " ", "",};

        assertEquals(ArrayUtils.toString(tokens), expected.length, tokens.length);
        for (int i = 0; i < expected.length; i++) {
            assertTrue("token[" + i + "] was '" + tokens[i] + "' but was expected to be '" + expected[i] + "'",
                    ObjectUtils.equals(expected[i], tokens[i]));
        }

    }
 
源代码19 项目: openhab1-addons   文件: SerialMessage.java
/**
 * Constructor. Creates a new instance of the SerialMessage class from a
 * specified buffer, and subsequently sets the node ID.
 *
 * @param nodeId the node the message is destined for
 * @param buffer the buffer to create the SerialMessage from.
 */
public SerialMessage(int nodeId, byte[] buffer) {
    logger.trace("NODE {}: Creating new SerialMessage from buffer = {}", nodeId, SerialMessage.bb2hex(buffer));
    messageLength = buffer.length - 2; // buffer[1];
    byte messageCheckSumm = calculateChecksum(buffer);
    byte messageCheckSummReceived = buffer[messageLength + 1];
    if (messageCheckSumm == messageCheckSummReceived) {
        logger.trace("NODE {}: Checksum matched", nodeId);
        isValid = true;
    } else {
        logger.trace("NODE {}: Checksum error. Calculated = 0x%02X, Received = 0x%02X", nodeId, messageCheckSumm,
                messageCheckSummReceived);
        isValid = false;
        return;
    }
    this.priority = SerialMessagePriority.High;
    this.messageType = buffer[2] == 0x00 ? SerialMessageType.Request : SerialMessageType.Response;
    this.messageClass = SerialMessageClass.getMessageClass(buffer[3] & 0xFF);
    this.messagePayload = ArrayUtils.subarray(buffer, 4, messageLength + 1);
    this.messageNode = nodeId;
    logger.trace("NODE {}: Message payload = {}", getMessageNode(), SerialMessage.bb2hex(messagePayload));
}
 
源代码20 项目: systemds   文件: TfMetaUtils.java
public static int[] parseJsonObjectIDList(JSONObject spec, String[] colnames, String group) 
	throws JSONException
{
	int[] colList = new int[0];
	boolean ids = spec.containsKey("ids") && spec.getBoolean("ids");
	
	if( spec.containsKey(group) && spec.get(group) instanceof JSONArray )
	{
		JSONArray colspecs = (JSONArray)spec.get(group);
		colList = new int[colspecs.size()];
		for(int j=0; j<colspecs.size(); j++) {
			JSONObject colspec = (JSONObject) colspecs.get(j);
			colList[j] = ids ? colspec.getInt("id") : 
				(ArrayUtils.indexOf(colnames, colspec.get("name")) + 1);
			if( colList[j] <= 0 ) {
				throw new RuntimeException("Specified column '" +
					colspec.get(ids?"id":"name")+"' does not exist.");
			}
		}
		
		//ensure ascending order of column IDs
		Arrays.sort(colList);
	}
	
	return colList;
}
 
源代码21 项目: freehealth-connector   文件: HandlersLoader.java
static Handler<?>[] addingDefaultHandlers(Handler<?>[] result) {
   ArrayList<Class> requiredHandler = new ArrayList(defaultHandlers.size());
   requiredHandler.addAll(defaultHandlers);
   CollectionUtils.filter(requiredHandler, new HandlersLoader.DefaultHandlersPredicate(result));
   Iterator i$ = requiredHandler.iterator();

   while(i$.hasNext()) {
      Class handler = (Class)i$.next();

      try {
         LOG.debug("Adding required handler [{}]", handler.getName());
         result = (Handler[])((Handler[])ArrayUtils.add(result, handler.newInstance()));
      } catch (Exception var5) {
         LOG.warn("Unable to add required handler", var5);
      }
   }

   return result;
}
 
源代码22 项目: canal-1.1.3   文件: LengthCodedStringReader.java
public String readLengthCodedString(byte[] data) throws IOException {
    byte[] lengthBytes = ByteHelper.readBinaryCodedLengthBytes(data, getIndex());
    long length = ByteHelper.readLengthCodedBinary(data, getIndex());
    setIndex(getIndex() + lengthBytes.length);
    if (ByteHelper.NULL_LENGTH == length) {
        return null;
    }

    try {
        return new String(ArrayUtils.subarray(data, getIndex(), (int) (getIndex() + length)),
            encoding == null ? CODE_PAGE_1252 : encoding);
    } finally {
        setIndex((int) (getIndex() + length));
    }

}
 
源代码23 项目: OpenLabeler   文件: TFTrainer.java
public static boolean isTraining() {
    List<Container> containers = dockerClient.listContainersCmd().withShowAll(true).exec();
    for (Container container : containers) {
        String name = Settings.getContainerName();
        if (ArrayUtils.isNotEmpty(container.getNames()) && container.getNames()[0].contains(name)) {
            return isRunning(container);
        }
    }
    return false;
}
 
源代码24 项目: freehealth-connector   文件: ConnectorIOUtils.java
public static byte[] base64Decode(byte[] input, boolean recursive) throws TechnicalConnectorException {
   byte[] result = ArrayUtils.clone(input);
   String content = toString(result, Charset.UTF_8);
   if (content.matches("^(?:[A-Za-z0-9+/]{4})*(?:[A-Za-z0-9+/]{2}==|[A-Za-z0-9+/]{3}=|[A-Za-z0-9+/]{4})$")) {
      result = Base64.decode(result);
      if (recursive) {
         result = base64Decode(result, recursive);
      }
   }

   return result;
}
 
@Test
public void testLongPredicateEvaluators() {
  long longValue = _random.nextLong();
  String stringValue = Long.toString(longValue);

  EqPredicate eqPredicate = new EqPredicate(COLUMN_EXPRESSION, stringValue);
  PredicateEvaluator eqPredicateEvaluator =
      EqualsPredicateEvaluatorFactory.newRawValueBasedEvaluator(eqPredicate, FieldSpec.DataType.LONG);

  NotEqPredicate notEqPredicate = new NotEqPredicate(COLUMN_EXPRESSION, stringValue);
  PredicateEvaluator neqPredicateEvaluator =
      NotEqualsPredicateEvaluatorFactory.newRawValueBasedEvaluator(notEqPredicate, FieldSpec.DataType.LONG);

  Assert.assertTrue(eqPredicateEvaluator.applySV(longValue));
  Assert.assertFalse(neqPredicateEvaluator.applySV(longValue));

  long[] randomLongs = new long[NUM_MULTI_VALUES];
  PredicateEvaluatorTestUtils.fillRandom(randomLongs);
  randomLongs[_random.nextInt(NUM_MULTI_VALUES)] = longValue;

  Assert.assertTrue(eqPredicateEvaluator.applyMV(randomLongs, NUM_MULTI_VALUES));
  Assert.assertFalse(neqPredicateEvaluator.applyMV(randomLongs, NUM_MULTI_VALUES));

  for (int i = 0; i < 100; i++) {
    long random = _random.nextLong();
    Assert.assertEquals(eqPredicateEvaluator.applySV(random), (random == longValue));
    Assert.assertEquals(neqPredicateEvaluator.applySV(random), (random != longValue));

    PredicateEvaluatorTestUtils.fillRandom(randomLongs);
    Assert.assertEquals(eqPredicateEvaluator.applyMV(randomLongs, NUM_MULTI_VALUES),
        ArrayUtils.contains(randomLongs, longValue));
    Assert.assertEquals(neqPredicateEvaluator.applyMV(randomLongs, NUM_MULTI_VALUES),
        !ArrayUtils.contains(randomLongs, longValue));
  }
}
 
源代码26 项目: mall   文件: ShoppingCartServiceImpl.java
/**
 * 查询购物车信息
 *
 * @param customerId 会员ID
 * @param ids        购物车id
 * @return 返回购物车信息
 */
@Log
private List<ShoppingCart> queryShoppingCarts(long customerId, Long[] ids) {
    if (ArrayUtils.isEmpty(ids)) {
        return shoppingCartMapper.queryShoppingCart(customerId);
    } else {
        Map<String, Object> params = new HashMap<>();
        params.put("customerId", customerId);
        params.put("ids", ids);
        return shoppingCartMapper.queryShoppingCartByIds(params);
    }

}
 
源代码27 项目: freehealth-connector   文件: OcspRef.java
OcspRef(byte[] inOcspEncoded) {
   this.ocspEncoded = ArrayUtils.clone(inOcspEncoded);

   try {
      this.ocsp = (BasicOCSPResp)(new OCSPResp(this.ocspEncoded)).getResponseObject();
   } catch (Exception var3) {
      throw new IllegalArgumentException(var3);
   }
}
 
源代码28 项目: pentaho-kettle   文件: StepMeta.java
private void setDeprecationAndSuggestedStep() {
  PluginRegistry registry = PluginRegistry.getInstance();
  final List<PluginInterface> deprecatedSteps = registry.getPluginsByCategory( StepPluginType.class,
    BaseMessages.getString( PKG, "BaseStep.Category.Deprecated" ) );
  for ( PluginInterface p : deprecatedSteps ) {
    String[] ids = p.getIds();
    if ( !ArrayUtils.isEmpty( ids ) && ids[0].equals( this.stepid ) ) {
      this.isDeprecated = true;
      this.suggestion = registry.findPluginWithId( StepPluginType.class, this.stepid ) != null
        ? registry.findPluginWithId( StepPluginType.class, this.stepid ).getSuggestion() : "";
      break;
    }
  }
}
 
源代码29 项目: systemds   文件: FrameBlock.java
/**
 * Append a column of value type STRING as the last column of 
 * the data frame. The given array is wrapped but not copied 
 * and hence might be updated in the future.
 * 
 * @param col array of strings
 */
public void appendColumn(String[] col) {
	ensureColumnCompatibility(col.length);
	String[] colnames = getColumnNames(); //before schema modification
	_schema = (ValueType[]) ArrayUtils.add(_schema, ValueType.STRING);
	_colnames = (String[]) ArrayUtils.add(colnames, createColName(_schema.length));
	_coldata = (_coldata==null) ? new Array[]{new StringArray(col)} :
		(Array[]) ArrayUtils.add(_coldata, new StringArray(col));
	_numRows = col.length;

}
 
源代码30 项目: GyJdbc   文件: Result.java
public PageResult<E> pageQuery(Page page) throws Exception {
    Object pageParams[] = {};
    String pageSql = "SELECT SQL_CALC_FOUND_ROWS * FROM (" + sql + ") temp ";
    pageSql = pageSql + " LIMIT ?,?";
    pageParams = ArrayUtils.addAll(params, new Object[]{page.getOffset(), page.getPageSize()});
    List<E> paged = jdbcTemplate.query(pageSql, pageParams, BeanPropertyRowMapper.newInstance(type));
    String countSql = "SELECT FOUND_ROWS() ";
    int count = jdbcTemplate.queryForObject(countSql, Integer.class);
    return new PageResult(paged, count);
}
 
 类所在包
 同包方法