Modifier and Type | Method and Description |
---|---|
void |
StoreRateLimiting.setMaxRate(ByteSizeValue rate) |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
ClusterStatsNodes.OsStats.getAvailableMemory() |
ByteSizeValue |
ClusterStatsNodes.JvmStats.getHeapMax()
Maximum total heap available to the cluster
|
ByteSizeValue |
ClusterStatsNodes.JvmStats.getHeapUsed()
Total heap used in the cluster
|
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
CommonStats.getTotalMemory()
Utility method which computes total memory by adding
FieldData, IdCache, Percolate, Segments (memory, index writer, version map)
|
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
PeerRecoveryStatus.getExpectedRecoveredIndexSize()
Deprecated.
|
ByteSizeValue |
GatewayRecoveryStatus.getExpectedRecoveredIndexSize()
Deprecated.
|
ByteSizeValue |
GatewaySnapshotStatus.getIndexSize()
Deprecated.
|
ByteSizeValue |
PeerRecoveryStatus.getIndexSize()
Deprecated.
|
ByteSizeValue |
GatewayRecoveryStatus.getIndexSize()
Deprecated.
|
ByteSizeValue |
IndexShardStatus.getPrimaryStoreSize()
Deprecated.
Returns only the primary shards store size in bytes.
|
ByteSizeValue |
IndexStatus.getPrimaryStoreSize()
Deprecated.
Returns only the primary shards store size in bytes.
|
ByteSizeValue |
PeerRecoveryStatus.getRecoveredIndexSize()
Deprecated.
How much of the index has been recovered.
|
ByteSizeValue |
GatewayRecoveryStatus.getRecoveredIndexSize()
Deprecated.
How much of the index has been recovered.
|
ByteSizeValue |
PeerRecoveryStatus.getReusedIndexSize()
Deprecated.
|
ByteSizeValue |
GatewayRecoveryStatus.getReusedIndexSize()
Deprecated.
|
ByteSizeValue |
IndexShardStatus.getStoreSize()
Deprecated.
Returns the full store size in bytes, of both primaries and replicas.
|
ByteSizeValue |
ShardStatus.getStoreSize()
Deprecated.
The current size of the shard index storage.
|
ByteSizeValue |
IndexStatus.getStoreSize()
Deprecated.
Returns the full store size in bytes, of both primaries and replicas.
|
Modifier and Type | Method and Description |
---|---|
BulkProcessor.Builder |
BulkProcessor.Builder.setBulkSize(ByteSizeValue bulkSize)
Sets when to flush a new bulk request based on the size of actions currently added.
|
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
DiskThresholdDecider.getFreeBytesThresholdHigh() |
ByteSizeValue |
DiskThresholdDecider.getFreeBytesThresholdLow() |
ByteSizeValue |
DiskThresholdDecider.thresholdBytesFromWatermark(String watermark)
Attempts to parse the watermark into a
ByteSizeValue , returning
a ByteSizeValue of 0 bytes if the value cannot be parsed. |
Constructor and Description |
---|
MemoryCircuitBreaker(ByteSizeValue limit,
double overheadConstant,
ESLogger logger)
Create a circuit breaker that will break if the number of estimated
bytes grows above the limit.
|
MemoryCircuitBreaker(ByteSizeValue limit,
double overheadConstant,
MemoryCircuitBreaker oldBreaker,
ESLogger logger)
Create a circuit breaker that will break if the number of estimated
bytes grows above the limit.
|
Modifier and Type | Field and Description |
---|---|
static ByteSizeValue |
NetworkService.TcpSettings.TCP_DEFAULT_RECEIVE_BUFFER_SIZE |
static ByteSizeValue |
NetworkService.TcpSettings.TCP_DEFAULT_SEND_BUFFER_SIZE |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
ImmutableSettings.getAsBytesSize(String[] settings,
ByteSizeValue defaultValue) |
ByteSizeValue |
Settings.getAsBytesSize(String[] settings,
ByteSizeValue defaultValue)
Returns the setting value (as size) associated with the setting key.
|
ByteSizeValue |
ImmutableSettings.getAsBytesSize(String setting,
ByteSizeValue defaultValue) |
ByteSizeValue |
Settings.getAsBytesSize(String setting,
ByteSizeValue defaultValue)
Returns the setting value (as size) associated with the setting key.
|
ByteSizeValue |
ImmutableSettings.getAsMemory(String[] settings,
String defaultValue) |
ByteSizeValue |
Settings.getAsMemory(String[] setting,
String defaultValue)
Returns the setting value (as size) associated with the setting key.
|
ByteSizeValue |
ImmutableSettings.getAsMemory(String setting,
String defaultValue) |
ByteSizeValue |
Settings.getAsMemory(String setting,
String defaultValue)
Returns the setting value (as size) associated with the setting key.
|
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
ImmutableSettings.getAsBytesSize(String[] settings,
ByteSizeValue defaultValue) |
ByteSizeValue |
Settings.getAsBytesSize(String[] settings,
ByteSizeValue defaultValue)
Returns the setting value (as size) associated with the setting key.
|
ByteSizeValue |
ImmutableSettings.getAsBytesSize(String setting,
ByteSizeValue defaultValue) |
ByteSizeValue |
Settings.getAsBytesSize(String setting,
ByteSizeValue defaultValue)
Returns the setting value (as size) associated with the setting key.
|
Modifier and Type | Method and Description |
---|---|
static ByteSizeValue |
ByteSizeValue.parseBytesSizeValue(String sValue) |
static ByteSizeValue |
ByteSizeValue.parseBytesSizeValue(String sValue,
ByteSizeValue defaultValue) |
static ByteSizeValue |
MemorySizeValue.parseBytesSizeValueOrHeapRatio(String sValue)
Parse the provided string as a memory size.
|
static ByteSizeValue |
ByteSizeValue.readBytesSizeValue(StreamInput in) |
Modifier and Type | Method and Description |
---|---|
static ByteSizeValue |
ByteSizeValue.parseBytesSizeValue(String sValue,
ByteSizeValue defaultValue) |
Modifier and Type | Method and Description |
---|---|
XContentBuilder |
XContentBuilder.byteSizeField(XContentBuilderString rawFieldName,
XContentBuilderString readableFieldName,
ByteSizeValue byteSizeValue) |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
HttpInfo.getMaxContentLength() |
ByteSizeValue |
HttpInfo.maxContentLength() |
Modifier and Type | Field and Description |
---|---|
protected ByteSizeValue |
NettyHttpServerTransport.maxChunkSize |
protected ByteSizeValue |
NettyHttpServerTransport.maxContentLength |
protected ByteSizeValue |
NettyHttpServerTransport.maxCumulationBufferCapacity |
protected ByteSizeValue |
NettyHttpServerTransport.maxHeaderSize |
protected ByteSizeValue |
NettyHttpServerTransport.maxInitialLineLength |
protected ByteSizeValue |
NettyHttpServerTransport.tcpReceiveBufferSize |
protected ByteSizeValue |
NettyHttpServerTransport.tcpSendBufferSize |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
FilterCacheStats.getMemorySize() |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
IdCacheStats.getMemorySize()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
QueryCacheStats.getMemorySize() |
Modifier and Type | Field and Description |
---|---|
static ByteSizeValue |
EngineConfig.DEFAUTL_INDEX_BUFFER_SIZE |
static ByteSizeValue |
EngineConfig.INACTIVE_SHARD_INDEXING_BUFFER |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
SegmentsStats.getFixedBitSetMemory() |
ByteSizeValue |
EngineConfig.getIndexingBufferSize()
Returns the initial index buffer size.
|
ByteSizeValue |
SegmentsStats.getIndexWriterMaxMemory() |
ByteSizeValue |
SegmentsStats.getIndexWriterMemory() |
ByteSizeValue |
SegmentsStats.getMemory() |
ByteSizeValue |
Segment.getSize() |
ByteSizeValue |
SegmentsStats.getVersionMapMemory() |
ByteSizeValue |
EngineConfig.getVersionMapSize()
returns the size of the version map that should trigger a refresh
|
Modifier and Type | Method and Description |
---|---|
void |
EngineConfig.setIndexingBufferSize(ByteSizeValue indexingBufferSize)
Sets the indexing buffer
|
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
FieldDataStats.getMemorySize() |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
MergeStats.getCurrentSize() |
ByteSizeValue |
MergeStats.getTotalSize() |
Modifier and Type | Field and Description |
---|---|
static ByteSizeValue |
TieredMergePolicyProvider.DEFAULT_FLOOR_SEGMENT |
static ByteSizeValue |
LogByteSizeMergePolicyProvider.DEFAULT_MAX_MERGE_SIZE |
static ByteSizeValue |
TieredMergePolicyProvider.DEFAULT_MAX_MERGED_SEGMENT |
static ByteSizeValue |
LogByteSizeMergePolicyProvider.DEFAULT_MIN_MERGE_SIZE |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
PercolateStats.getMemorySize() |
Modifier and Type | Method and Description |
---|---|
void |
IndexShard.updateBufferSize(ByteSizeValue shardIndexingBufferSize,
ByteSizeValue shardTranslogBufferSize) |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
BlobStoreIndexShardSnapshot.FileInfo.partSize()
Returns part size
|
Modifier and Type | Method and Description |
---|---|
void |
BlobStoreIndexShardRepository.initialize(BlobStore blobStore,
BlobPath basePath,
ByteSizeValue chunkSize,
org.apache.lucene.store.RateLimiter snapshotRateLimiter,
org.apache.lucene.store.RateLimiter restoreRateLimiter,
BlobStoreIndexShardRepository.RateLimiterListener rateLimiterListener)
Called by
BlobStoreRepository on repository startup |
Constructor and Description |
---|
FileInfo(String name,
StoreFileMetaData metaData,
ByteSizeValue partSize)
Constructs a new instance of file info
|
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
StoreStats.getSize() |
ByteSizeValue |
StoreStats.size() |
Modifier and Type | Field and Description |
---|---|
static ByteSizeValue |
Translog.INACTIVE_SHARD_TRANSLOG_BUFFER |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
TranslogStats.translogSizeInBytes() |
Modifier and Type | Method and Description |
---|---|
void |
Translog.updateBuffer(ByteSizeValue bufferSize) |
Modifier and Type | Method and Description |
---|---|
void |
FsTranslog.updateBuffer(ByteSizeValue bufferSize) |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
IndexingMemoryController.indexingBufferSize()
returns the current budget for the total amount of indexing buffers of
active shards on this node
|
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
RecoverySettings.fileChunkSize() |
ByteSizeValue |
RecoverFilesRecoveryException.totalFilesSize() |
ByteSizeValue |
RecoverySettings.translogSize() |
Constructor and Description |
---|
RecoverFilesRecoveryException(ShardId shardId,
int numberOfFiles,
ByteSizeValue totalFilesSize,
Throwable cause) |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
FsStats.Info.getAvailable() |
ByteSizeValue |
FsStats.Info.getDiskReadSizeSize() |
ByteSizeValue |
FsStats.Info.getDiskWriteSizeSize() |
ByteSizeValue |
FsStats.Info.getFree() |
ByteSizeValue |
FsStats.Info.getTotal() |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
JvmStats.GarbageCollector.LastGc.afterUsed() |
ByteSizeValue |
JvmStats.GarbageCollector.LastGc.beforeUsed() |
ByteSizeValue |
JvmInfo.Mem.directMemoryMax() |
ByteSizeValue |
JvmStats.GarbageCollector.LastGc.getAfterUsed() |
ByteSizeValue |
JvmStats.GarbageCollector.LastGc.getBeforeUsed() |
ByteSizeValue |
JvmInfo.Mem.getDirectMemoryMax() |
ByteSizeValue |
JvmStats.Mem.getHeapCommitted() |
ByteSizeValue |
JvmInfo.Mem.getHeapInit() |
ByteSizeValue |
JvmStats.Mem.getHeapMax()
returns the maximum heap size.
|
ByteSizeValue |
JvmInfo.Mem.getHeapMax() |
ByteSizeValue |
JvmStats.Mem.getHeapUsed() |
ByteSizeValue |
JvmStats.GarbageCollector.LastGc.getMax() |
ByteSizeValue |
JvmStats.MemoryPool.getMax() |
ByteSizeValue |
JvmStats.Mem.getNonHeapCommitted() |
ByteSizeValue |
JvmInfo.Mem.getNonHeapInit() |
ByteSizeValue |
JvmInfo.Mem.getNonHeapMax() |
ByteSizeValue |
JvmStats.Mem.getNonHeapUsed() |
ByteSizeValue |
JvmStats.MemoryPool.getPeakMax() |
ByteSizeValue |
JvmStats.MemoryPool.getPeakUsed() |
ByteSizeValue |
JvmStats.GarbageCollector.LastGc.getReclaimed() |
ByteSizeValue |
JvmStats.BufferPool.getTotalCapacity() |
ByteSizeValue |
JvmStats.MemoryPool.getUsed() |
ByteSizeValue |
JvmStats.BufferPool.getUsed() |
ByteSizeValue |
JvmStats.Mem.heapCommitted() |
ByteSizeValue |
JvmInfo.Mem.heapInit() |
ByteSizeValue |
JvmStats.Mem.heapMax()
returns the maximum heap size.
|
ByteSizeValue |
JvmInfo.Mem.heapMax() |
ByteSizeValue |
JvmStats.Mem.heapUsed() |
ByteSizeValue |
JvmStats.GarbageCollector.LastGc.max() |
ByteSizeValue |
JvmStats.MemoryPool.max() |
ByteSizeValue |
JvmStats.Mem.nonHeapCommitted() |
ByteSizeValue |
JvmInfo.Mem.nonHeapInit() |
ByteSizeValue |
JvmInfo.Mem.nonHeapMax() |
ByteSizeValue |
JvmStats.Mem.nonHeapUsed() |
ByteSizeValue |
JvmStats.MemoryPool.peakMax() |
ByteSizeValue |
JvmStats.MemoryPool.peakUsed() |
ByteSizeValue |
JvmStats.GarbageCollector.LastGc.reclaimed() |
ByteSizeValue |
JvmStats.BufferPool.totalCapacity() |
ByteSizeValue |
JvmStats.MemoryPool.used() |
ByteSizeValue |
JvmStats.BufferPool.used() |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
OsStats.Mem.actualFree() |
ByteSizeValue |
OsStats.Mem.actualUsed() |
ByteSizeValue |
OsInfo.Cpu.cacheSize() |
ByteSizeValue |
OsStats.Swap.free() |
ByteSizeValue |
OsStats.Mem.free() |
ByteSizeValue |
OsStats.Mem.getActualFree() |
ByteSizeValue |
OsStats.Mem.getActualUsed() |
ByteSizeValue |
OsInfo.Cpu.getCacheSize() |
ByteSizeValue |
OsStats.Swap.getFree() |
ByteSizeValue |
OsStats.Mem.getFree() |
ByteSizeValue |
OsInfo.Swap.getTotal() |
ByteSizeValue |
OsInfo.Mem.getTotal() |
ByteSizeValue |
OsStats.Swap.getUsed() |
ByteSizeValue |
OsStats.Mem.getUsed() |
ByteSizeValue |
OsInfo.Swap.total() |
ByteSizeValue |
OsInfo.Mem.total() |
ByteSizeValue |
OsStats.Swap.used() |
ByteSizeValue |
OsStats.Mem.used() |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
ProcessStats.Mem.getResident() |
ByteSizeValue |
ProcessStats.Mem.getShare() |
ByteSizeValue |
ProcessStats.Mem.getTotalVirtual() |
ByteSizeValue |
ProcessStats.Mem.resident() |
ByteSizeValue |
ProcessStats.Mem.share() |
ByteSizeValue |
ProcessStats.Mem.totalVirtual() |
Modifier and Type | Method and Description |
---|---|
protected ByteSizeValue |
BlobStoreRepository.chunkSize()
Returns data file chunk size.
|
Modifier and Type | Method and Description |
---|---|
protected ByteSizeValue |
FsRepository.chunkSize()
Returns data file chunk size.
|
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
RestRequest.paramAsSize(String key,
ByteSizeValue defaultValue) |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
RestRequest.paramAsSize(String key,
ByteSizeValue defaultValue) |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
CompletionStats.getSize() |
Modifier and Type | Method and Description |
---|---|
ByteSizeValue |
TransportStats.getRxSize() |
ByteSizeValue |
TransportStats.getTxSize() |
ByteSizeValue |
TransportStats.rxSize() |
ByteSizeValue |
TransportStats.txSize() |
Modifier and Type | Field and Description |
---|---|
protected ByteSizeValue |
NettyTransport.maxCumulationBufferCapacity |
protected ByteSizeValue |
NettyTransport.receivePredictorMax |
protected ByteSizeValue |
NettyTransport.receivePredictorMin |
Copyright © 2009–2015. All rights reserved.