org.elasticsearch.common.unit.TimeValue.millis()方法的使用及代码示例

x33g5p2x  于2022-01-29 转载在 其他  
字(8.9k)|赞(0)|评价(0)|浏览(118)

本文整理了Java中org.elasticsearch.common.unit.TimeValue.millis()方法的一些代码示例,展示了TimeValue.millis()的具体用法。这些代码示例主要来源于Github/Stackoverflow/Maven等平台,是从一些精选项目中提取出来的代码,具有较强的参考意义,能在一定程度帮忙到你。TimeValue.millis()方法的具体详情如下:
包路径:org.elasticsearch.common.unit.TimeValue
类名称:TimeValue
方法名:millis

TimeValue.millis介绍

暂无

代码示例

代码示例来源:origin: spring-projects/spring-data-elasticsearch

@Override
public <T> CloseableIterator<T> stream(CriteriaQuery query, Class<T> clazz) {
  final long scrollTimeInMillis = TimeValue.timeValueMinutes(1).millis();
  return doStream(scrollTimeInMillis, (ScrolledPage<T>) startScroll(scrollTimeInMillis, query, clazz), clazz,
      resultsMapper);
}

代码示例来源:origin: spring-projects/spring-data-elasticsearch

@Override
public <T> CloseableIterator<T> stream(SearchQuery query, final Class<T> clazz, final SearchResultMapper mapper) {
  final long scrollTimeInMillis = TimeValue.timeValueMinutes(1).millis();
  return doStream(scrollTimeInMillis, (ScrolledPage<T>) startScroll(scrollTimeInMillis, query, clazz, mapper), clazz,
      mapper);
}

代码示例来源:origin: richardwilly98/elasticsearch-river-mongodb

@Override
public void run() {
  while (context.getStatus() == Status.RUNNING) {
    try {
      Timestamp<?> lastTimestamp = null;
      // 1. Attempt to fill as much of the bulk request as possible
      QueueEntry entry = context.getStream().take();
      lastTimestamp = processBlockingQueue(entry);
      while ((entry = context.getStream().poll(definition.getBulk().getFlushInterval().millis(), MILLISECONDS)) != null) {
        lastTimestamp = processBlockingQueue(entry);
      }
      // 2. Update the timestamp
      if (lastTimestamp != null) {
        river.setLastTimestamp(lastTimestamp,
            getBulkProcessor(definition.getIndexName(), definition.getTypeName()).getBulkProcessor());
      }
    } catch (InterruptedException e) {
      logger.info("river-mongodb indexer interrupted");
      releaseProcessors();
      Thread.currentThread().interrupt();
      break;
    }
  }
}

代码示例来源:origin: org.elasticsearch/elasticsearch

/**
   * Returns <code>true</code> iff the cache needs to be refreshed.
   */
  protected boolean needsRefresh() {
    if (refreshInterval.millis() == 0) {
      return true;
    }
    final long currentTime = System.currentTimeMillis();
    return (currentTime - lastRefreshTimestamp) > refreshInterval.millis();
  }
}

代码示例来源:origin: org.elasticsearch/elasticsearch

public Builder(TimeValue interval) {
  this.unit = null;
  if (interval.millis() < 1)
    throw new IllegalArgumentException("Zero or negative time interval not supported");
  this.interval = interval.millis();
}

代码示例来源:origin: org.elasticsearch/elasticsearch

/**
 * Sets a connect timeout for this connection profile
 */
public Builder setConnectTimeout(TimeValue connectTimeout) {
  if (connectTimeout.millis() < 0) {
    throw new IllegalArgumentException("connectTimeout must be non-negative but was: " + connectTimeout);
  }
  this.connectTimeout = connectTimeout;
  return this;
}

代码示例来源:origin: org.elasticsearch/elasticsearch

private static TimeValue checkDelay(TimeValue delay) {
  if (delay.millis() > Integer.MAX_VALUE) {
    throw new IllegalArgumentException("delay must be <= " + Integer.MAX_VALUE + " ms");
  }
  return delay;
}

代码示例来源:origin: org.elasticsearch/elasticsearch

private void setKeepAlives(TimeValue defaultKeepAlive, TimeValue maxKeepAlive) {
  validateKeepAlives(defaultKeepAlive, maxKeepAlive);
  this.defaultKeepAlive = defaultKeepAlive.millis();
  this.maxKeepAlive = maxKeepAlive.millis();
}

代码示例来源:origin: org.elasticsearch/elasticsearch

public static TimeValue parseTimeValue(String s, TimeValue minValue, String key) {
  TimeValue timeValue = TimeValue.parseTimeValue(s, null, key);
  if (timeValue.millis() < minValue.millis()) {
    throw new IllegalArgumentException("Failed to parse value [" + s + "] for setting [" + key + "] must be >= " + minValue);
  }
  return timeValue;
}

代码示例来源:origin: org.elasticsearch/elasticsearch

static long parseStringOffset(String offset) {
  if (offset.charAt(0) == '-') {
    return -TimeValue
        .parseTimeValue(offset.substring(1), null, DateHistogramAggregationBuilder.class.getSimpleName() + ".parseOffset")
        .millis();
  }
  int beginIndex = offset.charAt(0) == '+' ? 1 : 0;
  return TimeValue
      .parseTimeValue(offset.substring(beginIndex), null, DateHistogramAggregationBuilder.class.getSimpleName() + ".parseOffset")
      .millis();
}

代码示例来源:origin: org.elasticsearch/elasticsearch

@Override
public Map<Class<?>, XContentBuilder.HumanReadableTransformer> getXContentHumanReadableTransformers() {
  Map<Class<?>, XContentBuilder.HumanReadableTransformer> transformers = new HashMap<>();
  transformers.put(TimeValue.class, v -> ((TimeValue) v).millis());
  transformers.put(ByteSizeValue.class, v -> ((ByteSizeValue) v).getBytes());
  return transformers;
}

代码示例来源:origin: org.elasticsearch/elasticsearch

private BulkResponse getAccumulatedResponse() {
  BulkItemResponse[] itemResponses;
  synchronized (responses) {
    itemResponses = responses.toArray(new BulkItemResponse[1]);
  }
  long stopTimestamp = System.nanoTime();
  long totalLatencyMs = TimeValue.timeValueNanos(stopTimestamp - startTimestampNanos).millis();
  return new BulkResponse(itemResponses, totalLatencyMs);
}

代码示例来源:origin: org.elasticsearch/elasticsearch

private void retry(BulkRequest bulkRequestForRetry) {
  assert backoff.hasNext();
  TimeValue next = backoff.next();
  logger.trace("Retry of bulk request scheduled in {} ms.", next.millis());
  Runnable command = scheduler.preserveContext(() -> this.execute(bulkRequestForRetry));
  scheduledRequestFuture = scheduler.schedule(next, ThreadPool.Names.SAME, command);
}

代码示例来源:origin: org.elasticsearch/elasticsearch

/**
 * Creates an new exponential backoff policy with the provided configuration.
 *
 * @param initialDelay       The initial delay defines how long to wait for the first retry attempt. Must not be null.
 *                           Must be &lt;= <code>Integer.MAX_VALUE</code> ms.
 * @param maxNumberOfRetries The maximum number of retries. Must be a non-negative number.
 * @return A backoff policy with an exponential increase in wait time for retries. The returned instance is thread safe but each
 * iterator created from it should only be used by a single thread.
 */
public static BackoffPolicy exponentialBackoff(TimeValue initialDelay, int maxNumberOfRetries) {
  return new ExponentialBackoff((int) checkDelay(initialDelay).millis(), maxNumberOfRetries);
}

代码示例来源:origin: org.elasticsearch/elasticsearch

private UnicastPingResponse handlePingRequest(final UnicastPingRequest request) {
  assert clusterName.equals(request.pingResponse.clusterName()) :
    "got a ping request from a different cluster. expected " + clusterName + " got " + request.pingResponse.clusterName();
  temporalResponses.add(request.pingResponse);
  // add to any ongoing pinging
  activePingingRounds.values().forEach(p -> p.addPingResponseToCollection(request.pingResponse));
  threadPool.schedule(TimeValue.timeValueMillis(request.timeout.millis() * 2), ThreadPool.Names.SAME,
    () -> temporalResponses.remove(request.pingResponse));
  List<PingResponse> pingResponses = CollectionUtils.iterableAsArrayList(temporalResponses);
  pingResponses.add(createPingResponse(contextProvider.clusterState()));
  return new UnicastPingResponse(request.id, pingResponses.toArray(new PingResponse[pingResponses.size()]));
}

代码示例来源:origin: org.elasticsearch/elasticsearch

/**
 * Validates the join request, throwing a failure if it failed.
 */
public void sendValidateJoinRequestBlocking(DiscoveryNode node, ClusterState state, TimeValue timeout) {
  transportService.submitRequest(node, DISCOVERY_JOIN_VALIDATE_ACTION_NAME, new ValidateJoinRequest(state),
    EmptyTransportResponseHandler.INSTANCE_SAME).txGet(timeout.millis(), TimeUnit.MILLISECONDS);
}

代码示例来源:origin: org.elasticsearch/elasticsearch

public ProcessService(Settings settings) {
  this.probe = ProcessProbe.getInstance();
  final TimeValue refreshInterval = REFRESH_INTERVAL_SETTING.get(settings);
  processStatsCache = new ProcessStatsCache(refreshInterval, probe.processStats());
  this.info = probe.processInfo(refreshInterval.millis());
  logger.debug("using refresh_interval [{}]", refreshInterval);
}

代码示例来源:origin: org.elasticsearch/elasticsearch

public CheckedBiConsumer<Transport.Connection, ConnectionProfile, IOException> connectionValidator(DiscoveryNode node) {
  return (newConnection, actualProfile) -> {
    // We don't validate cluster names to allow for CCS connections.
    final DiscoveryNode remote = handshake(newConnection, actualProfile.getHandshakeTimeout().millis(), cn -> true).discoveryNode;
    if (validateConnections && node.equals(remote) == false) {
      throw new ConnectTransportException(node, "handshake failed. unexpected remote node " + remote);
    }
  };
}

代码示例来源:origin: org.elasticsearch/elasticsearch

public OsService(Settings settings) throws IOException {
  this.probe = OsProbe.getInstance();
  TimeValue refreshInterval = REFRESH_INTERVAL_SETTING.get(settings);
  this.info = probe.osInfo(refreshInterval.millis(), EsExecutors.numberOfProcessors(settings));
  this.osStatsCache = new OsStatsCache(refreshInterval, probe.osStats());
  logger.debug("using refresh_interval [{}]", refreshInterval);
}

代码示例来源:origin: org.elasticsearch/elasticsearch

private void processScroll(InternalScrollSearchRequest request, SearchContext context) throws IOException {
  // process scroll
  context.from(context.from() + context.size());
  context.scrollContext().scroll = request.scroll();
  // update the context keep alive based on the new scroll value
  if (request.scroll() != null && request.scroll().keepAlive() != null) {
    contextScrollKeepAlive(context, request.scroll().keepAlive().millis());
  }
}

相关文章