Modifier and Type | Method and Description |
---|---|
T |
ActionFuture.actionGet(TimeValue timeout)
Similar to
Future.get(long, java.util.concurrent.TimeUnit) , just catching the InterruptedException and throwing
an ElasticsearchIllegalStateException instead. |
Response |
ActionRequestBuilder.get(TimeValue timeout)
Short version of execute().actionGet().
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
ClusterHealthRequest.timeout() |
Modifier and Type | Method and Description |
---|---|
ClusterHealthRequestBuilder |
ClusterHealthRequestBuilder.setTimeout(TimeValue timeout) |
ClusterHealthRequest |
ClusterHealthRequest.timeout(TimeValue timeout) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
NodesHotThreadsRequest.interval() |
Modifier and Type | Method and Description |
---|---|
NodesHotThreadsRequest |
NodesHotThreadsRequest.interval(TimeValue interval) |
NodesHotThreadsRequestBuilder |
NodesHotThreadsRequestBuilder.setInterval(TimeValue interval) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
NodesRestartRequest.delay() |
Modifier and Type | Method and Description |
---|---|
NodesRestartRequest |
NodesRestartRequest.delay(TimeValue delay)
The delay for the restart to occur.
|
NodesRestartRequestBuilder |
NodesRestartRequestBuilder.setDelay(TimeValue delay)
The delay for the restart to occur.
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
NodesShutdownRequest.delay() |
Modifier and Type | Method and Description |
---|---|
NodesShutdownRequest |
NodesShutdownRequest.delay(TimeValue delay)
The delay for the shutdown to occur.
|
NodesShutdownRequestBuilder |
NodesShutdownRequestBuilder.setDelay(TimeValue delay)
The delay for the restart to occur.
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
ClusterStatsNodes.JvmStats.getMaxUpTime()
The maximum uptime of a node in the cluster
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
DeleteIndexRequest.timeout()
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
|
Modifier and Type | Method and Description |
---|---|
DeleteIndexRequestBuilder |
DeleteIndexRequestBuilder.setTimeout(TimeValue timeout)
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
|
DeleteIndexRequest |
DeleteIndexRequest.timeout(TimeValue timeout)
Timeout to wait for the index deletion to be acknowledged by current cluster nodes.
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
GatewaySnapshotStatus.getTime()
Deprecated.
|
TimeValue |
PeerRecoveryStatus.getTime()
Deprecated.
|
TimeValue |
GatewayRecoveryStatus.getTime()
Deprecated.
|
Modifier and Type | Field and Description |
---|---|
protected TimeValue |
BulkRequest.timeout |
Modifier and Type | Method and Description |
---|---|
TimeValue |
BulkResponse.getTook()
How long the bulk execution took.
|
TimeValue |
BulkRequest.timeout() |
Modifier and Type | Method and Description |
---|---|
BulkProcessor.Builder |
BulkProcessor.Builder.setFlushInterval(TimeValue flushInterval)
Sets a flush interval flushing *any* bulk actions pending if the interval passes.
|
BulkRequestBuilder |
BulkRequestBuilder.setTimeout(TimeValue timeout)
A timeout to wait if the index operation can't be performed immediately.
|
BulkRequest |
BulkRequest.timeout(TimeValue timeout)
A timeout to wait if the index operation can't be performed immediately.
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
PercolateResponse.getTook()
How long the percolate took.
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
SearchResponse.getTook()
How long the search took.
|
Modifier and Type | Method and Description |
---|---|
SearchRequest |
SearchRequest.scroll(TimeValue keepAlive)
If set, will enable scrolling of the search request for the specified timeout.
|
SearchScrollRequest |
SearchScrollRequest.scroll(TimeValue keepAlive)
If set, will enable scrolling of the search request for the specified timeout.
|
SearchRequestBuilder |
SearchRequestBuilder.setScroll(TimeValue keepAlive)
If set, will enable scrolling of the search request for the specified timeout.
|
SearchScrollRequestBuilder |
SearchScrollRequestBuilder.setScroll(TimeValue keepAlive)
If set, will enable scrolling of the search request for the specified timeout.
|
SearchRequestBuilder |
SearchRequestBuilder.setTimeout(TimeValue timeout)
An optional timeout to control how long search is allowed to take.
|
Modifier and Type | Method and Description |
---|---|
T |
AdapterActionFuture.actionGet(TimeValue timeout) |
Modifier and Type | Field and Description |
---|---|
static TimeValue |
AcknowledgedRequest.DEFAULT_ACK_TIMEOUT |
static TimeValue |
MasterNodeOperationRequest.DEFAULT_MASTER_NODE_TIMEOUT |
protected TimeValue |
MasterNodeOperationRequest.masterNodeTimeout |
protected TimeValue |
AcknowledgedRequest.timeout |
Modifier and Type | Method and Description |
---|---|
TimeValue |
AcknowledgedRequest.ackTimeout() |
TimeValue |
MasterNodeOperationRequest.masterNodeTimeout() |
TimeValue |
AcknowledgedRequest.timeout()
Returns the current timeout
|
Modifier and Type | Method and Description |
---|---|
T |
MasterNodeOperationRequest.masterNodeTimeout(TimeValue timeout)
A timeout value in case the master has not been discovered yet or disconnected.
|
RequestBuilder |
MasterNodeOperationRequestBuilder.setMasterNodeTimeout(TimeValue timeout)
Sets the master node timeout in case the master has not yet been discovered.
|
RequestBuilder |
AcknowledgedRequestBuilder.setTimeout(TimeValue timeout)
Sets the maximum wait for acknowledgement from other nodes
|
T |
AcknowledgedRequest.timeout(TimeValue timeout)
Allows to set the timeout
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
NodesOperationRequest.timeout() |
Modifier and Type | Method and Description |
---|---|
RequestBuilder |
NodesOperationRequestBuilder.setTimeout(TimeValue timeout) |
T |
NodesOperationRequest.timeout(TimeValue timeout) |
Modifier and Type | Field and Description |
---|---|
static TimeValue |
ShardReplicationOperationRequest.DEFAULT_TIMEOUT |
protected TimeValue |
IndicesReplicationOperationRequest.timeout |
protected TimeValue |
ShardReplicationOperationRequest.timeout |
Modifier and Type | Method and Description |
---|---|
TimeValue |
IndicesReplicationOperationRequest.timeout() |
TimeValue |
IndexReplicationOperationRequest.timeout() |
TimeValue |
ShardReplicationOperationRequest.timeout() |
Modifier and Type | Method and Description |
---|---|
RequestBuilder |
ShardReplicationOperationRequestBuilder.setTimeout(TimeValue timeout)
A timeout to wait if the index operation can't be performed immediately.
|
RequestBuilder |
IndicesReplicationOperationRequestBuilder.setTimeout(TimeValue timeout)
A timeout to wait if the index operation can't be performed immediately.
|
T |
IndicesReplicationOperationRequest.timeout(TimeValue timeout)
A timeout to wait if the delete by query operation can't be performed immediately.
|
T |
ShardReplicationOperationRequest.timeout(TimeValue timeout)
A timeout to wait if the index operation can't be performed immediately.
|
Constructor and Description |
---|
IndexReplicationOperationRequest(String index,
TimeValue timeout,
ReplicationType replicationType,
WriteConsistencyLevel consistencyLevel,
String[] originalIndices,
IndicesOptions originalIndicesOptions,
ActionRequest request) |
Modifier and Type | Field and Description |
---|---|
static TimeValue |
InstanceShardOperationRequest.DEFAULT_TIMEOUT |
protected TimeValue |
InstanceShardOperationRequest.timeout |
Modifier and Type | Method and Description |
---|---|
TimeValue |
InstanceShardOperationRequest.timeout() |
Modifier and Type | Method and Description |
---|---|
RequestBuilder |
InstanceShardOperationRequestBuilder.setTimeout(TimeValue timeout)
A timeout to wait if the index operation can't be performed immediately.
|
T |
InstanceShardOperationRequest.timeout(TimeValue timeout)
A timeout to wait if the index operation can't be performed immediately.
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
TermVectorResponse.getTook() |
Modifier and Type | Method and Description |
---|---|
TimeValue |
AckedClusterStateUpdateTask.ackTimeout()
Acknowledgement timeout, maximum time interval to wait for acknowledgements
|
TimeValue |
AckedClusterStateUpdateTask.timeout() |
abstract TimeValue |
TimeoutClusterStateUpdateTask.timeout()
If the cluster state update task wasn't processed by the provided timeout, call
ClusterStateUpdateTask.onFailure(String, Throwable) |
Modifier and Type | Method and Description |
---|---|
void |
ClusterService.add(TimeValue timeout,
TimeoutClusterStateListener listener)
Adds a cluster state listener that will timeout after the provided timeout,
and is executed after the clusterstate has been successfully applied ie.
|
void |
ClusterStateObserver.Listener.onTimeout(TimeValue timeout) |
void |
TimeoutClusterStateListener.onTimeout(TimeValue timeout) |
void |
ClusterStateObserver.waitForNextChange(ClusterStateObserver.Listener listener,
ClusterStateObserver.ChangePredicate changePredicate,
TimeValue timeOutValue)
Wait for the next cluster state which satisfies changePredicate
|
void |
ClusterStateObserver.waitForNextChange(ClusterStateObserver.Listener listener,
TimeValue timeOutValue) |
Constructor and Description |
---|
ClusterStateObserver(ClusterService clusterService,
TimeValue timeout,
ESLogger logger) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
AckedRequest.ackTimeout()
Returns the acknowledgement timeout
|
TimeValue |
ClusterStateUpdateRequest.ackTimeout()
Returns the maximum time interval to wait for acknowledgements
|
TimeValue |
AckedRequest.masterNodeTimeout()
Returns the timeout for the request to be completed on the master node
|
TimeValue |
ClusterStateUpdateRequest.masterNodeTimeout()
Returns the maximum time interval to wait for the request to
be completed on the master node
|
Modifier and Type | Method and Description |
---|---|
T |
ClusterStateUpdateRequest.ackTimeout(TimeValue ackTimeout)
Sets the acknowledgement timeout
|
T |
ClusterStateUpdateRequest.masterNodeTimeout(TimeValue masterNodeTimeout)
Sets the master node timeout
|
Modifier and Type | Method and Description |
---|---|
MetaDataDeleteIndexService.Request |
MetaDataDeleteIndexService.Request.masterTimeout(TimeValue masterTimeout) |
MetaDataIndexTemplateService.PutRequest |
MetaDataIndexTemplateService.PutRequest.masterTimeout(TimeValue masterTimeout) |
MetaDataIndexTemplateService.RemoveRequest |
MetaDataIndexTemplateService.RemoveRequest.masterTimeout(TimeValue masterTimeout) |
MetaDataDeleteIndexService.Request |
MetaDataDeleteIndexService.Request.timeout(TimeValue timeout) |
Constructor and Description |
---|
ProcessClusterEventTimeoutException(TimeValue timeValue,
String source) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
DiskThresholdDecider.getRerouteInterval() |
Modifier and Type | Method and Description |
---|---|
TimeValue |
PendingClusterTask.getTimeInQueue() |
Modifier and Type | Method and Description |
---|---|
void |
InternalClusterService.add(TimeValue timeout,
TimeoutClusterStateListener listener) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
StopWatch.TaskInfo.getTime()
Return the time this task took.
|
TimeValue |
StopWatch.lastTaskTime()
Return the time taken by the last task.
|
TimeValue |
StopWatch.totalTime()
Return the total time for all tasks.
|
Modifier and Type | Method and Description |
---|---|
boolean |
HttpDownloadHelper.download(URL source,
File dest,
HttpDownloadHelper.DownloadProgress progress,
TimeValue timeout) |
Modifier and Type | Field and Description |
---|---|
static TimeValue |
NetworkService.TcpSettings.TCP_DEFAULT_CONNECT_TIMEOUT |
Modifier and Type | Method and Description |
---|---|
static TimeZoneRounding.Builder |
TimeZoneRounding.builder(TimeValue interval) |
Constructor and Description |
---|
Builder(TimeValue interval) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
ImmutableSettings.getAsTime(String[] settings,
TimeValue defaultValue) |
TimeValue |
Settings.getAsTime(String[] settings,
TimeValue defaultValue)
Returns the setting value (as time) associated with the setting key.
|
TimeValue |
ImmutableSettings.getAsTime(String setting,
TimeValue defaultValue) |
TimeValue |
Settings.getAsTime(String setting,
TimeValue defaultValue)
Returns the setting value (as time) associated with the setting key.
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
ImmutableSettings.getAsTime(String[] settings,
TimeValue defaultValue) |
TimeValue |
Settings.getAsTime(String[] settings,
TimeValue defaultValue)
Returns the setting value (as time) associated with the setting key.
|
TimeValue |
ImmutableSettings.getAsTime(String setting,
TimeValue defaultValue) |
TimeValue |
Settings.getAsTime(String setting,
TimeValue defaultValue)
Returns the setting value (as time) associated with the setting key.
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
Fuzziness.asTimeValue() |
static TimeValue |
TimeValue.parseTimeValue(String sValue,
TimeValue defaultValue) |
static TimeValue |
TimeValue.readTimeValue(StreamInput in) |
static TimeValue |
TimeValue.timeValueHours(long hours) |
static TimeValue |
TimeValue.timeValueMillis(long millis) |
static TimeValue |
TimeValue.timeValueMinutes(long minutes) |
static TimeValue |
TimeValue.timeValueNanos(long nanos) |
static TimeValue |
TimeValue.timeValueSeconds(long seconds) |
Modifier and Type | Method and Description |
---|---|
static TimeValue |
TimeValue.parseTimeValue(String sValue,
TimeValue defaultValue) |
Constructor and Description |
---|
SingleObjectCache(TimeValue refreshInterval,
T initialValue) |
Modifier and Type | Method and Description |
---|---|
void |
PrioritizedEsThreadPoolExecutor.execute(Runnable command,
ScheduledExecutorService timer,
TimeValue timeout,
Runnable timeoutCallback) |
Modifier and Type | Method and Description |
---|---|
XContentBuilder |
XContentBuilder.timeValueField(XContentBuilderString rawFieldName,
XContentBuilderString readableFieldName,
TimeValue timeValue) |
Modifier and Type | Method and Description |
---|---|
static TimeValue |
XContentMapValues.nodeTimeValue(Object node) |
static TimeValue |
XContentMapValues.nodeTimeValue(Object node,
TimeValue defaultValue) |
Modifier and Type | Method and Description |
---|---|
static TimeValue |
XContentMapValues.nodeTimeValue(Object node,
TimeValue defaultValue) |
Modifier and Type | Field and Description |
---|---|
static TimeValue |
DiscoverySettings.DEFAULT_PUBLISH_TIMEOUT |
Modifier and Type | Method and Description |
---|---|
TimeValue |
DiscoverySettings.getPublishTimeout()
Returns the current publish timeout
|
Modifier and Type | Method and Description |
---|---|
boolean |
BlockingClusterStatePublishResponseHandler.awaitAllNodes(TimeValue timeout)
Allows to wait for all non master nodes to reply to the publish event up to a timeout
|
Modifier and Type | Field and Description |
---|---|
protected TimeValue |
FaultDetection.pingInterval |
protected TimeValue |
FaultDetection.pingRetryTimeout |
Modifier and Type | Method and Description |
---|---|
void |
MembershipAction.sendJoinRequestBlocking(DiscoveryNode masterNode,
DiscoveryNode node,
TimeValue timeout) |
void |
MembershipAction.sendLeaveRequestBlocking(DiscoveryNode masterNode,
DiscoveryNode node,
TimeValue timeout) |
void |
MembershipAction.sendValidateJoinRequestBlocking(DiscoveryNode node,
TimeValue timeout)
Validates the join request, throwing a failure if it failed.
|
Modifier and Type | Method and Description |
---|---|
void |
ZenPingService.ping(ZenPing.PingListener listener,
TimeValue timeout) |
void |
ZenPing.ping(ZenPing.PingListener listener,
TimeValue timeout) |
ZenPing.PingResponse[] |
ZenPingService.pingAndWait(TimeValue timeout) |
Modifier and Type | Method and Description |
---|---|
void |
MulticastZenPing.ping(ZenPing.PingListener listener,
TimeValue timeout) |
ZenPing.PingResponse[] |
MulticastZenPing.pingAndWait(TimeValue timeout) |
Modifier and Type | Method and Description |
---|---|
void |
UnicastZenPing.ping(ZenPing.PingListener listener,
TimeValue timeout) |
ZenPing.PingResponse[] |
UnicastZenPing.pingAndWait(TimeValue timeout) |
Modifier and Type | Field and Description |
---|---|
static TimeValue |
GatewayService.DEFAULT_RECOVER_AFTER_TIME_IF_EXPECTED_NODES_IS_SET |
Modifier and Type | Method and Description |
---|---|
TimeValue |
GatewayService.recoverAfterTime() |
Modifier and Type | Method and Description |
---|---|
ActionFuture<TransportNodesListGatewayMetaState.NodesLocalGatewayMetaState> |
TransportNodesListGatewayMetaState.list(String[] nodesIds,
TimeValue timeout) |
Modifier and Type | Method and Description |
---|---|
ActionFuture<TransportNodesListGatewayStartedShards.NodesLocalGatewayStartedShards> |
TransportNodesListGatewayStartedShards.list(ShardId shardId,
String[] nodesIds,
TimeValue timeout) |
Modifier and Type | Field and Description |
---|---|
static TimeValue |
EngineConfig.DEFAULT_GC_DELETES |
static TimeValue |
ShadowEngine.DEFAULT_NONEXISTENT_INDEX_RETRY_WAIT |
static TimeValue |
EngineConfig.DEFAULT_REFRESH_INTERVAL |
Modifier and Type | Method and Description |
---|---|
TimeValue |
FlushStats.getTotalTime()
The total time merges have been executed.
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
GetStats.getExistsTime() |
TimeValue |
GetStats.getMissingTime() |
TimeValue |
GetStats.getTime() |
Modifier and Type | Method and Description |
---|---|
TimeValue |
IndexingStats.Stats.getDeleteTime() |
TimeValue |
IndexingStats.Stats.getIndexTime() |
TimeValue |
IndexingStats.Stats.getThrottleTime()
Gets the amount of time in a TimeValue that the index has been under merge throttling control
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
MergeStats.getTotalTime()
The total time merges have been executed.
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
PercolateStats.getTime() |
Modifier and Type | Method and Description |
---|---|
TimeValue |
RecoveryStats.throttleTime()
Total time recoveries waited due to throttling
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
RefreshStats.getTotalTime()
The total time merges have been executed.
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
SearchStats.Stats.getFetchTime() |
TimeValue |
SearchStats.Stats.getQueryTime() |
Modifier and Type | Method and Description |
---|---|
TimeValue |
StoreStats.getThrottleTime() |
TimeValue |
StoreStats.throttleTime() |
Modifier and Type | Method and Description |
---|---|
TimeValue |
SuggestStats.getTime() |
Modifier and Type | Method and Description |
---|---|
TimeValue |
WarmerStats.totalTime()
The total time warmer have been executed.
|
Modifier and Type | Method and Description |
---|---|
void |
IndicesService.processPendingDeletes(Index index,
Settings indexSettings,
TimeValue timeout)
Processes all pending deletes for the given index.
|
Constructor and Description |
---|
FieldDataCacheCleaner(com.google.common.cache.Cache cache,
ESLogger logger,
ThreadPool threadPool,
TimeValue interval) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
RecoverySettings.activityTimeout() |
TimeValue |
RecoverySettings.internalActionLongTimeout() |
TimeValue |
RecoverySettings.internalActionTimeout() |
TimeValue |
RecoverySettings.retryDelayNetwork() |
TimeValue |
RecoverySettings.retryDelayStateSync() |
TimeValue |
RecoveryState.Index.sourceThrottling() |
TimeValue |
RecoveryState.Index.targetThrottling() |
Modifier and Type | Method and Description |
---|---|
protected void |
RecoveryTarget.retryRecovery(RecoveryStatus recoveryStatus,
String reason,
TimeValue retryAfter,
StartRecoveryRequest currentRequest) |
long |
RecoveriesCollection.startRecovery(IndexShard indexShard,
DiscoveryNode sourceNode,
RecoveryTarget.RecoveryListener listener,
TimeValue activityTimeout)
Starts are new recovery for the given shard, source node and state
|
Modifier and Type | Method and Description |
---|---|
ActionFuture<TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData> |
TransportNodesListShardStoreMetaData.list(ShardId shardId,
boolean onlyUnallocated,
String[] nodesIds,
TimeValue timeout) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
JvmStats.GarbageCollector.collectionTime() |
TimeValue |
JvmStats.GarbageCollector.LastGc.duration() |
TimeValue |
JvmStats.GarbageCollector.getCollectionTime() |
TimeValue |
JvmStats.GarbageCollector.LastGc.getDuration() |
TimeValue |
JvmStats.getUptime() |
TimeValue |
JvmStats.uptime() |
Modifier and Type | Method and Description |
---|---|
HotThreads |
HotThreads.interval(TimeValue interval) |
HotThreads |
HotThreads.threadElementsSnapshotDelay(TimeValue threadElementsSnapshotDelay) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
OsStats.getUptime() |
TimeValue |
OsStats.uptime() |
Modifier and Type | Method and Description |
---|---|
TimeValue |
ProcessStats.Cpu.getSys()
Get the Process cpu kernel time.
|
TimeValue |
ProcessStats.Cpu.getTotal()
Get the Process cpu time (sum of User and Sys).
|
TimeValue |
ProcessStats.Cpu.getUser()
Get the Process cpu user time.
|
TimeValue |
ProcessStats.Cpu.sys()
Get the Process cpu kernel time.
|
TimeValue |
ProcessStats.Cpu.total()
Get the Process cpu time (sum of User and Sys).
|
TimeValue |
ProcessStats.Cpu.user()
Get the Process cpu user time.
|
Modifier and Type | Field and Description |
---|---|
static TimeValue |
PluginManager.DEFAULT_TIMEOUT |
Constructor and Description |
---|
PluginManager(Environment environment,
String url,
PluginManager.OutputMode outputMode,
TimeValue timeout) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
RestRequest.paramAsTime(String key,
TimeValue defaultValue) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
RestRequest.paramAsTime(String key,
TimeValue defaultValue) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
Scroll.keepAlive()
How long the resources will be kept open to support the scroll request.
|
Constructor and Description |
---|
Scroll(TimeValue keepAlive)
Constructs a new scroll of the provided keep alive.
|
Modifier and Type | Method and Description |
---|---|
SearchSourceBuilder |
SearchSourceBuilder.timeout(TimeValue timeout)
An optional timeout to control how long search is allowed to take.
|
Modifier and Type | Method and Description |
---|---|
DateHistogramFacetBuilder |
DateHistogramFacetBuilder.postOffset(TimeValue postOffset)
Sets a post offset that will be applied after rounding the results.
|
DateHistogramFacetBuilder |
DateHistogramFacetBuilder.preOffset(TimeValue preOffset)
Sets a pre offset that will be applied before rounding the results.
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
SnapshotsService.SnapshotRequest.masterNodeTimeout()
Returns master node timeout
|
TimeValue |
RestoreService.RestoreRequest.masterNodeTimeout()
Return master node timeout
|
Modifier and Type | Method and Description |
---|---|
SnapshotsService.SnapshotRequest |
SnapshotsService.SnapshotRequest.masterNodeTimeout(TimeValue masterNodeTimeout)
Sets master node timeout
|
Constructor and Description |
---|
RestoreRequest(String cause,
String repository,
String name,
String[] indices,
IndicesOptions indicesOptions,
String renamePattern,
String renameReplacement,
Settings settings,
TimeValue masterNodeTimeout,
boolean includeGlobalState,
boolean partial,
boolean includeAliases,
Settings indexSettings,
String[] ignoreIndexSettings)
Constructs new restore request
|
Modifier and Type | Method and Description |
---|---|
TimeValue |
ThreadPool.Info.getKeepAlive() |
Modifier and Type | Method and Description |
---|---|
ScheduledFuture<?> |
ThreadPool.schedule(TimeValue delay,
String name,
Runnable command) |
ScheduledFuture<?> |
ThreadPool.scheduleWithFixedDelay(Runnable command,
TimeValue interval) |
Constructor and Description |
---|
Info(String name,
String type,
int min,
int max,
TimeValue keepAlive,
SizeValue queueSize) |
Modifier and Type | Method and Description |
---|---|
TimeValue |
TransportRequestOptions.timeout() |
Modifier and Type | Method and Description |
---|---|
TransportRequestOptions |
TransportRequestOptions.withTimeout(TimeValue timeout) |
Modifier and Type | Field and Description |
---|---|
protected TimeValue |
NettyTransport.connectTimeout |
Copyright © 2009–2015. All rights reserved.