• 设为首页
  • 点击收藏
  • 手机版
    手机扫一扫访问
    迪恩网络手机版
  • 关注官方公众号
    微信扫一扫关注
    迪恩网络公众号

Java BulkConnection类代码示例

原作者: [db:作者] 来自: [db:来源] 收藏 邀请

本文整理汇总了Java中com.sforce.async.BulkConnection的典型用法代码示例。如果您正苦于以下问题:Java BulkConnection类的具体用法?Java BulkConnection怎么用?Java BulkConnection使用的例子?那么恭喜您, 这里精选的类代码示例或许可以为您提供帮助。



BulkConnection类属于com.sforce.async包,在下文中一共展示了BulkConnection类的20个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于我们的系统推荐出更棒的Java代码示例。

示例1: createBulkConnection

import com.sforce.async.BulkConnection; //导入依赖的package包/类
private BulkConnection createBulkConnection(ConnectorConfig partnerConfig)
        throws AsyncApiException {

    ConnectorConfig config = new ConnectorConfig();
    config.setSessionId(partnerConfig.getSessionId());

    String soapEndpoint = partnerConfig.getServiceEndpoint();
    String restEndpoint = soapEndpoint.substring(
            0, soapEndpoint.indexOf("Soap/")) + "async/" + API_VERSION;
    config.setRestEndpoint(restEndpoint);
    config.setCompression(isCompression);

    config.setTraceMessage(false);

    return new BulkConnection(config);
}
 
开发者ID:mikoto2000,项目名称:embulk-input-salesforce_bulk,代码行数:17,代码来源:SalesforceBulkWrapper.java


示例2: createJob

import com.sforce.async.BulkConnection; //导入依赖的package包/类
private JobInfo createJob(String sobjectType, BulkConnection connection)
        throws AsyncApiException {
  JobInfo job = new JobInfo();
  job.setObject(sobjectType);
  job.setOperation(conf.queryAll ? OperationEnum.queryAll : OperationEnum.query);
  job.setContentType(ContentType.CSV);
  if (conf.usePKChunking) {
    String headerValue = CHUNK_SIZE + "=" + conf.chunkSize;
    if (!StringUtils.isEmpty(conf.startId)) {
      headerValue += "; " + START_ROW + "=" + conf.startId;
    }
    connection.addHeader(SFORCE_ENABLE_PKCHUNKING, headerValue);
  }
  job = connection.createJob(job);
  return job;
}
 
开发者ID:streamsets,项目名称:datacollector,代码行数:17,代码来源:ForceSource.java


示例3: createBulkConnection

import com.sforce.async.BulkConnection; //导入依赖的package包/类
private void createBulkConnection() throws AsyncApiException
{
    // check if connection has already been created
    if (getBulkConnection() != null)
    {
        // connection already created
        return;
    }

    // print the info we will use to build the connection
    Utils.log("SalesforceService::createBulkConnection() entered" + "\n\tSession ID:    " + getSessionId()
        + "\n\tBulk Endpoint: " + getBulkEndpoint());

    // create partner connector configuration
    ConnectorConfig bulkConfig = getConnectorConfig(getServerUrl(), getSessionId());
    bulkConfig.setSessionId(getSessionId());
    bulkConfig.setRestEndpoint(getBulkEndpoint());
    bulkConfig.setCompression(true);

    // check if tracing is enabled
    if (getenv(SALESFORCE_TRACE_BULK) != null && getenv(SALESFORCE_TRACE_BULK).equalsIgnoreCase("1"))
    {
        // set this to true to see HTTP requests and responses on stdout
        bulkConfig.setTraceMessage(true);
        bulkConfig.setPrettyPrintXml(true);

        // this should only be false when doing debugging.
        bulkConfig.setCompression(false);
    }

    setBulkConnection(new BulkConnection(bulkConfig));
}
 
开发者ID:forcedotcom,项目名称:scmt-server,代码行数:33,代码来源:SalesforceService.java


示例4: getBulkConnection

import com.sforce.async.BulkConnection; //导入依赖的package包/类
public static BulkConnection getBulkConnection(
    ConnectorConfig partnerConfig,
    ForceConfigBean conf
) throws ConnectionException, AsyncApiException, StageException, URISyntaxException {
  // When PartnerConnection is instantiated, a login is implicitly
  // executed and, if successful,
  // a valid session is stored in the ConnectorConfig instance.
  // Use this key to initialize a BulkConnection:
  ConnectorConfig config = conf.mutualAuth.useMutualAuth
      ? new MutualAuthConnectorConfig(conf.mutualAuth.getUnderlyingConfig().getSslContext())
      : new ConnectorConfig();
  config.setSessionId(partnerConfig.getSessionId());

  // The endpoint for the Bulk API service is the same as for the normal
  // SOAP uri until the /Soap/ part. From here it's '/async/versionNumber'
  String soapEndpoint = partnerConfig.getServiceEndpoint();
  String restEndpoint = soapEndpoint.substring(0, soapEndpoint.indexOf("Soap/"))
      + "async/" + conf.apiVersion;
  config.setRestEndpoint(restEndpoint);
  config.setCompression(conf.useCompression);
  config.setTraceMessage(conf.showTrace);
  config.setSessionRenewer(partnerConfig.getSessionRenewer());

  setProxyConfig(conf, config);

  BulkConnection bulkConnection = new BulkConnection(config);

  if (conf.mutualAuth.useMutualAuth) {
    setupMutualAuthBulk(config, conf.mutualAuth);
  }

  return bulkConnection;
}
 
开发者ID:streamsets,项目名称:datacollector,代码行数:34,代码来源:ForceUtils.java


示例5: createBatchesForApexClasses

import com.sforce.async.BulkConnection; //导入依赖的package包/类
public List<BatchInfo> createBatchesForApexClasses(BulkConnection bulkConnection, JobInfo jobInfo,
		String[] testClassesAsArray) {

	List<BatchInfo> batchInfos = new ArrayList<BatchInfo>();
	String stringToFeedIntoTheBatch = "ApexClassId\n";
	for (String testClass : testClassesAsArray) {
		stringToFeedIntoTheBatch += testClass;
		stringToFeedIntoTheBatch += "\n";
	}
	InputStream inputStream = new ByteArrayInputStream(stringToFeedIntoTheBatch.getBytes());

	batchInfos = createBatch(inputStream, batchInfos, jobInfo, bulkConnection);

	return batchInfos;
}
 
开发者ID:forcedotcom,项目名称:ApexUnit,代码行数:16,代码来源:AsyncBulkApiHandler.java


示例6: awaitCompletion

import com.sforce.async.BulkConnection; //导入依赖的package包/类
/**
 * Wait for a job to complete by polling the Bulk API.
 * 
 * @param connection
 *            BulkConnection used to check results.
 * @param job
 *            The job awaiting completion.
 * @param batchInfoList
 *            List of batches for this job.
 * @throws AsyncApiException
 */
public void awaitCompletion(BulkConnection connection, JobInfo job, List<BatchInfo> batchInfoList)
		throws AsyncApiException {
	long sleepTime = 0L;
	Set<String> incompleteBatchInfos = new HashSet<String>();
	for (BatchInfo bi : batchInfoList) {
		incompleteBatchInfos.add(bi.getId());
	}
	while (!incompleteBatchInfos.isEmpty()) {
		try {
			Thread.sleep(sleepTime);
		} catch (InterruptedException e) {
			ApexUnitUtils
					.shutDownWithDebugLog(e, "InterruptedException encountered while the thread was attempting to sleep");
		}
		LOG.debug("Awaiting results... Batches remaining for processing: " + incompleteBatchInfos.size());
		sleepTime = 10000L;
		BatchInfo[] statusList = connection.getBatchInfoList(job.getId()).getBatchInfo();
		for (BatchInfo batchInfo : statusList) {
			// Retain the BatchInfo's which are in InProgress and Queued
			// status,
			// Remove the rest from the incompleteBatchInfos
			if (batchInfo.getState() == BatchStateEnum.Completed) {
				if (incompleteBatchInfos.remove(batchInfo.getId())) {
					LOG.debug("BATCH STATUS:" + batchInfo.getStateMessage());
				}
			} else if (batchInfo.getState() == BatchStateEnum.NotProcessed) {
				LOG.info("Batch " + batchInfo.getId() + " did not process, terminating it");
				incompleteBatchInfos.remove(batchInfo.getId());
			} else if (batchInfo.getState() == BatchStateEnum.Failed) {
				ApexUnitUtils.shutDownWithErrMsg("BATCH STATUS:" + batchInfo.getStateMessage());
			}
		}
	}
}
 
开发者ID:forcedotcom,项目名称:ApexUnit,代码行数:46,代码来源:AsyncBulkApiHandler.java


示例7: checkResults

import com.sforce.async.BulkConnection; //导入依赖的package包/类
/**
 * Gets the results of the operation and checks for errors.
 */
public List<SaveResult> checkResults(BulkConnection bulkConnection, JobInfo job, List<BatchInfo> batchInfoList)
		throws AsyncApiException, IOException {
	LOG.debug("Checking Results.... ");
	List<SaveResult> saveResults = new ArrayList<SaveResult>();

	// batchInfoList was populated when batches were created and submitted
	for (BatchInfo batchInfo : batchInfoList) {
		CSVReader csvReaderForBatchResultStream = new CSVReader(
				bulkConnection.getBatchResultStream(job.getId(), batchInfo.getId()));
		List<String> resultHeader = csvReaderForBatchResultStream.nextRecord();
		int resultCols = resultHeader.size();

		List<String> batchResultStream = null;
		while ((batchResultStream = csvReaderForBatchResultStream.nextRecord()) != null) {

			Map<String, String> resultInfo = new HashMap<String, String>();
			for (int i = 0; i < resultCols; i++) {
				resultInfo.put(resultHeader.get(i), batchResultStream.get(i));
			}
			SaveResult sr = new SaveResult();
			sr.setId(resultInfo.get("Id"));
			boolean success = Boolean.valueOf(resultInfo.get("Success"));
			sr.setSuccess(success);

			if (!success) {
				if (resultInfo.get("Error") != null && StringUtils.isNotEmpty(resultInfo.get("Error"))) {
					ApexUnitUtils.shutDownWithErrMsg(
							"Error while fetching results for the batch job" + resultInfo.get("Error"));
				}
			}

			saveResults.add(sr);
		}
	}

	return saveResults;
}
 
开发者ID:forcedotcom,项目名称:ApexUnit,代码行数:41,代码来源:AsyncBulkApiHandler.java


示例8: createBulkConnection

import com.sforce.async.BulkConnection; //导入依赖的package包/类
private BulkConnection createBulkConnection() {
	
	BulkConnectionConnectorConfig bcConnectorConfig = new BulkConnectionConnectorConfig();
	ConnectorConfig config = bcConnectorConfig.createConfig();
	try {
		bulkConnection = new BulkConnection(config);
		LOG.info("Bulk connection established.");
	} catch (AsyncApiException e) {
		ApexUnitUtils
				.shutDownWithDebugLog(e, "Caught AsyncApiException exception while trying to deal with bulk connection: "
						+ e.getMessage());
	}
	return bulkConnection;
}
 
开发者ID:forcedotcom,项目名称:ApexUnit,代码行数:15,代码来源:ConnectionHandler.java


示例9: SalesforceBulkRuntime

import com.sforce.async.BulkConnection; //导入依赖的package包/类
public SalesforceBulkRuntime(BulkConnection bulkConnection) throws IOException {
    this.bulkConnection = bulkConnection;
    if (this.bulkConnection == null) {
        throw new RuntimeException(
                "Please check \"Bulk Connection\" checkbox in the setting of the referenced tSalesforceConnection.");
    }
}
 
开发者ID:Talend,项目名称:components,代码行数:8,代码来源:SalesforceBulkRuntime.java


示例10: connectBulk

import com.sforce.async.BulkConnection; //导入依赖的package包/类
protected BulkConnection connectBulk(ConnectorConfig config) throws ComponentException {
    /*
     * When PartnerConnection is instantiated, a login is implicitly executed and, if successful, a valid session is
     * stored in the ConnectorConfig instance. Use this key to initialize a BulkConnection:
     */
    ConnectorConfig bulkConfig = new ConnectorConfig();
    bulkConfig.setSessionId(config.getSessionId());
    // For session renew
    bulkConfig.setSessionRenewer(config.getSessionRenewer());
    bulkConfig.setUsername(config.getUsername());
    bulkConfig.setPassword(config.getPassword());
    /*
     * The endpoint for the Bulk API service is the same as for the normal SOAP uri until the /Soap/ part. From here
     * it's '/async/versionNumber'
     */
    String soapEndpoint = config.getServiceEndpoint();
    // set it by a default property file
    String api_version = "34.0";
    String restEndpoint = soapEndpoint.substring(0, soapEndpoint.indexOf("Soap/")) + "async/" + api_version;
    bulkConfig.setRestEndpoint(restEndpoint);
    bulkConfig.setCompression(true);// This should only be false when doing debugging.
    bulkConfig.setTraceMessage(false);
    bulkConfig.setValidateSchema(false);
    try {
        return new BulkConnection(bulkConfig);
    } catch (AsyncApiException e) {
        throw new ComponentException(e);
    }
}
 
开发者ID:Talend,项目名称:components,代码行数:30,代码来源:SalesforceDataprepSource.java


示例11: connectBulk

import com.sforce.async.BulkConnection; //导入依赖的package包/类
protected BulkConnection connectBulk(ConnectorConfig config) throws ComponentException {
    final SalesforceConnectionProperties connProps = getConnectionProperties();
    /*
     * When PartnerConnection is instantiated, a login is implicitly executed and, if successful, a valid session id is
     * stored in the ConnectorConfig instance. Use this key to initialize a BulkConnection:
     */
    ConnectorConfig bulkConfig = new ConnectorConfig();
    setProxy(bulkConfig);
    bulkConfig.setSessionId(config.getSessionId());
    // For session renew
    bulkConfig.setSessionRenewer(config.getSessionRenewer());
    bulkConfig.setUsername(config.getUsername());
    bulkConfig.setPassword(config.getPassword());
    /*
     * The endpoint for the Bulk API service is the same as for the normal SOAP uri until the /Soap/ part. From here
     * it's '/async/versionNumber'
     */
    String soapEndpoint = config.getServiceEndpoint();
    // Service endpoint should be like this:
    // https://ap1.salesforce.com/services/Soap/u/37.0/00D90000000eSq3
    String apiVersion = soapEndpoint.substring(soapEndpoint.lastIndexOf("/services/Soap/u/") + 17);
    apiVersion = apiVersion.substring(0, apiVersion.indexOf("/"));
    String restEndpoint = soapEndpoint.substring(0, soapEndpoint.indexOf("Soap/")) + "async/" + apiVersion;
    bulkConfig.setRestEndpoint(restEndpoint);
    // This should only be false when doing debugging.
    bulkConfig.setCompression(connProps.needCompression.getValue());
    bulkConfig.setTraceMessage(connProps.httpTraceMessage.getValue());
    bulkConfig.setValidateSchema(false);
    try {
        return new BulkConnection(bulkConfig);
    } catch (AsyncApiException e) {
        throw new ComponentException(e);
    }
}
 
开发者ID:Talend,项目名称:components,代码行数:35,代码来源:SalesforceSourceOrSink.java


示例12: setUp

import com.sforce.async.BulkConnection; //导入依赖的package包/类
@Before
public void setUp() throws Exception {
    inputProperties = new TSalesforceInputProperties("input");

    conn = mock(BulkConnection.class);

    runtime = new SalesforceBulkRuntime(conn);
    assertTrue(conn == runtime.getBulkConnection());
}
 
开发者ID:Talend,项目名称:components,代码行数:10,代码来源:SalesforceBulkRuntimeTest.java


示例13: getBulkConnection

import com.sforce.async.BulkConnection; //导入依赖的package包/类
private BulkConnection getBulkConnection()
{
    return _bConn;
}
 
开发者ID:forcedotcom,项目名称:scmt-server,代码行数:5,代码来源:SalesforceService.java


示例14: setBulkConnection

import com.sforce.async.BulkConnection; //导入依赖的package包/类
private void setBulkConnection(BulkConnection bConn)
{
    this._bConn = bConn;
}
 
开发者ID:forcedotcom,项目名称:scmt-server,代码行数:5,代码来源:SalesforceService.java


示例15: bulkApiLogin

import com.sforce.async.BulkConnection; //导入依赖的package包/类
/**
 * Login to salesforce
   * @return login status
 */
public boolean bulkApiLogin() throws Exception {
  this.log.info("Authenticating salesforce bulk api");
  boolean success = false;
  String hostName = this.workUnit.getProp(ConfigurationKeys.SOURCE_CONN_HOST_NAME);
  String apiVersion = this.workUnit.getProp(ConfigurationKeys.SOURCE_CONN_VERSION);
  if (Strings.isNullOrEmpty(apiVersion)) {
    apiVersion = "29.0";
  }

  String soapAuthEndPoint = hostName + SALESFORCE_SOAP_AUTH_SERVICE + "/" + apiVersion;
  try {
    ConnectorConfig partnerConfig = new ConnectorConfig();
    if (super.workUnitState.contains(ConfigurationKeys.SOURCE_CONN_USE_PROXY_URL)
        && !super.workUnitState.getProp(ConfigurationKeys.SOURCE_CONN_USE_PROXY_URL).isEmpty()) {
      partnerConfig.setProxy(super.workUnitState.getProp(ConfigurationKeys.SOURCE_CONN_USE_PROXY_URL),
          super.workUnitState.getPropAsInt(ConfigurationKeys.SOURCE_CONN_USE_PROXY_PORT));
    }

    partnerConfig.setUsername(this.workUnit.getProp(ConfigurationKeys.SOURCE_CONN_USERNAME));
    partnerConfig.setPassword(PasswordManager.getInstance(this.workUnit)
        .readPassword(this.workUnit.getProp(ConfigurationKeys.SOURCE_CONN_PASSWORD)));
    partnerConfig.setAuthEndpoint(soapAuthEndPoint);
    PartnerConnection connection = new PartnerConnection(partnerConfig);
    String soapEndpoint = partnerConfig.getServiceEndpoint();
    String restEndpoint = soapEndpoint.substring(0, soapEndpoint.indexOf("Soap/")) + "async/" + apiVersion;

    ConnectorConfig config = new ConnectorConfig();
    config.setSessionId(partnerConfig.getSessionId());
    config.setRestEndpoint(restEndpoint);
    config.setCompression(true);
    config.setTraceFile("traceLogs.txt");
    config.setTraceMessage(false);
    config.setPrettyPrintXml(true);

    if (super.workUnitState.contains(ConfigurationKeys.SOURCE_CONN_USE_PROXY_URL)
        && !super.workUnitState.getProp(ConfigurationKeys.SOURCE_CONN_USE_PROXY_URL).isEmpty()) {
      config.setProxy(super.workUnitState.getProp(ConfigurationKeys.SOURCE_CONN_USE_PROXY_URL),
          super.workUnitState.getPropAsInt(ConfigurationKeys.SOURCE_CONN_USE_PROXY_PORT));
    }

    this.bulkConnection = new BulkConnection(config);
    success = true;
  } catch (Exception e) {
    throw new Exception("Failed to connect to salesforce bulk api; error - " + e.getMessage(), e);
  }
  return success;
}
 
开发者ID:Hanmourang,项目名称:Gobblin,代码行数:52,代码来源:SalesforceExtractor.java


示例16: ForceBulkWriter

import com.sforce.async.BulkConnection; //导入依赖的package包/类
public ForceBulkWriter(Map<String, String> fieldMappings, BulkConnection bulkConnection, Target.Context context) {
  super(fieldMappings);
  this.bulkConnection = bulkConnection;
  this.context = context;
}
 
开发者ID:streamsets,项目名称:datacollector,代码行数:6,代码来源:ForceBulkWriter.java


示例17: closeJob

import com.sforce.async.BulkConnection; //导入依赖的package包/类
public void closeJob(BulkConnection bulkConnection, String jobId) throws AsyncApiException {
	JobInfo job = new JobInfo();
	job.setId(jobId);
	job.setState(JobStateEnum.Closed);
	bulkConnection.updateJob(job);
}
 
开发者ID:forcedotcom,项目名称:ApexUnit,代码行数:7,代码来源:AsyncBulkApiHandler.java


示例18: getBulkConnection

import com.sforce.async.BulkConnection; //导入依赖的package包/类
public BulkConnection getBulkConnection() {
	if (bulkConnection == null) {
		createBulkConnection();
	}
	return bulkConnection;
}
 
开发者ID:forcedotcom,项目名称:ApexUnit,代码行数:7,代码来源:ConnectionHandler.java


示例19: setBulkConnection

import com.sforce.async.BulkConnection; //导入依赖的package包/类
public void setBulkConnection(BulkConnection bulkConnection) {
	this.bulkConnection = bulkConnection;
}
 
开发者ID:forcedotcom,项目名称:ApexUnit,代码行数:4,代码来源:ConnectionHandler.java


示例20: getBulkConnection

import com.sforce.async.BulkConnection; //导入依赖的package包/类
public BulkConnection getBulkConnection() {
    return bulkConnection;
}
 
开发者ID:Talend,项目名称:components,代码行数:4,代码来源:SalesforceBulkRuntime.java



注:本文中的com.sforce.async.BulkConnection类示例整理自Github/MSDocs等源码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。


鲜花

握手

雷人

路过

鸡蛋
该文章已有0人参与评论

请发表评论

全部评论

专题导读
上一篇:
Java DefaultHttpClient类代码示例发布时间:2022-05-23
下一篇:
Java StageHelper类代码示例发布时间:2022-05-23
热门推荐
阅读排行榜

扫描微信二维码

查看手机版网站

随时了解更新最新资讯

139-2527-9053

在线客服(服务时间 9:00~18:00)

在线QQ客服
地址:深圳市南山区西丽大学城创智工业园
电邮:jeky_zhao#qq.com
移动电话:139-2527-9053

Powered by 互联科技 X3.4© 2001-2213 极客世界.|Sitemap