Constructor and Description |
---|
NoShardAvailableActionException(ShardId shardId) |
NoShardAvailableActionException(ShardId shardId,
String msg) |
NoShardAvailableActionException(ShardId shardId,
String msg,
Throwable cause) |
UnavailableShardsException(ShardId shardId,
String message) |
Modifier and Type | Method and Description |
---|---|
com.google.common.collect.ImmutableMap<SnapshotId,com.google.common.collect.ImmutableMap<ShardId,SnapshotIndexShardStatus>> |
TransportNodesSnapshotsStatus.NodeSnapshotStatus.status() |
Constructor and Description |
---|
NodeSnapshotStatus(DiscoveryNode node,
com.google.common.collect.ImmutableMap<SnapshotId,com.google.common.collect.ImmutableMap<ShardId,SnapshotIndexShardStatus>> status) |
Modifier and Type | Method and Description |
---|---|
protected AnalyzeResponse |
TransportAnalyzeAction.shardOperation(AnalyzeRequest request,
ShardId shardId) |
Modifier and Type | Method and Description |
---|---|
protected GetFieldMappingsResponse |
TransportGetFieldMappingsIndexAction.shardOperation(org.elasticsearch.action.admin.indices.mapping.get.GetFieldMappingsIndexRequest request,
ShardId shardId) |
Modifier and Type | Method and Description |
---|---|
ShardId |
IndexShardSegments.getShardId() |
Modifier and Type | Method and Description |
---|---|
ShardId |
IndexShardStats.getShardId() |
Constructor and Description |
---|
IndexShardStats(ShardId shardId,
ShardStats[] shards) |
Modifier and Type | Method and Description |
---|---|
ShardId |
IndexShardStatus.getShardId()
Deprecated.
|
Modifier and Type | Method and Description |
---|---|
ShardId |
BulkShardResponse.getShardId() |
Modifier and Type | Method and Description |
---|---|
protected ExplainResponse |
TransportExplainAction.shardOperation(ExplainRequest request,
ShardId shardId) |
Modifier and Type | Method and Description |
---|---|
protected GetResponse |
TransportGetAction.shardOperation(GetRequest request,
ShardId shardId) |
protected MultiGetShardResponse |
TransportShardMultiGetAction.shardOperation(MultiGetShardRequest request,
ShardId shardId) |
Modifier and Type | Method and Description |
---|---|
protected TransportShardMultiPercolateAction.Response |
TransportShardMultiPercolateAction.shardOperation(TransportShardMultiPercolateAction.Request request,
ShardId shardId) |
Constructor and Description |
---|
PercolateShardResponse(org.apache.lucene.util.BytesRef[] matches,
List<Map<String,HighlightField>> hls,
long count,
float[] scores,
PercolateContext context,
ShardId shardId) |
PercolateShardResponse(org.apache.lucene.util.BytesRef[] matches,
List<Map<String,HighlightField>> hls,
long count,
PercolateContext context,
ShardId shardId) |
PercolateShardResponse(org.apache.lucene.util.BytesRef[] matches,
long count,
float[] scores,
PercolateContext context,
ShardId shardId) |
PercolateShardResponse(long count,
PercolateContext context,
ShardId shardId) |
PercolateShardResponse(PercolateContext context,
ShardId shardId) |
Modifier and Type | Method and Description |
---|---|
ShardId |
BroadcastShardOperationRequest.shardId() |
Constructor and Description |
---|
BroadcastShardOperationFailedException(ShardId shardId,
String msg) |
BroadcastShardOperationFailedException(ShardId shardId,
String msg,
Throwable cause) |
BroadcastShardOperationFailedException(ShardId shardId,
Throwable cause) |
BroadcastShardOperationRequest(ShardId shardId,
BroadcastOperationRequest request) |
BroadcastShardOperationRequest(ShardId shardId,
OriginalIndices originalIndices) |
BroadcastShardOperationResponse(ShardId shardId) |
Modifier and Type | Field and Description |
---|---|
ShardId |
TransportShardReplicationOperationAction.PrimaryOperationRequest.shardId |
ShardId |
TransportShardReplicationOperationAction.ReplicaOperationRequest.shardId |
Constructor and Description |
---|
ReplicationShardOperationFailedException(ShardId shardId,
String msg) |
ReplicationShardOperationFailedException(ShardId shardId,
String msg,
Throwable cause) |
ReplicationShardOperationFailedException(ShardId shardId,
Throwable cause) |
Modifier and Type | Method and Description |
---|---|
ShardId |
TransportSingleCustomOperationAction.ShardSingleOperationRequest.shardId() |
Modifier and Type | Method and Description |
---|---|
protected abstract Response |
TransportSingleCustomOperationAction.shardOperation(Request request,
ShardId shardId)
Operation to be executed at the shard level.
|
Constructor and Description |
---|
ShardSingleOperationRequest(Request request,
ShardId shardId) |
Modifier and Type | Method and Description |
---|---|
protected abstract Response |
TransportShardSingleOperationAction.shardOperation(Request request,
ShardId shardId) |
Modifier and Type | Method and Description |
---|---|
protected MultiTermVectorsShardResponse |
TransportSingleShardMultiTermsVectorAction.shardOperation(MultiTermVectorsShardRequest request,
ShardId shardId) |
protected TermVectorResponse |
TransportSingleShardTermVectorAction.shardOperation(TermVectorRequest request,
ShardId shardId) |
Modifier and Type | Method and Description |
---|---|
com.google.common.collect.ImmutableMap<ShardId,SnapshotMetaData.ShardSnapshotStatus> |
SnapshotMetaData.Entry.shards() |
com.google.common.collect.ImmutableMap<ShardId,RestoreMetaData.ShardRestoreStatus> |
RestoreMetaData.Entry.shards()
Returns list of shards that being restore and their status
|
com.google.common.collect.ImmutableMap<String,com.google.common.collect.ImmutableList<ShardId>> |
SnapshotMetaData.Entry.waitingIndices() |
Constructor and Description |
---|
Entry(SnapshotId snapshotId,
boolean includeGlobalState,
SnapshotMetaData.State state,
com.google.common.collect.ImmutableList<String> indices,
com.google.common.collect.ImmutableMap<ShardId,SnapshotMetaData.ShardSnapshotStatus> shards) |
Entry(SnapshotId snapshotId,
RestoreMetaData.State state,
com.google.common.collect.ImmutableList<String> indices,
com.google.common.collect.ImmutableMap<ShardId,RestoreMetaData.ShardRestoreStatus> shards)
Creates new restore metadata
|
Modifier and Type | Method and Description |
---|---|
ShardId |
IndexShardRoutingTable.getShardId()
Returns the shards id
|
ShardId |
ShardRouting.shardId()
The shard id.
|
ShardId |
ShardIterator.shardId()
The shard id this group relates to.
|
ShardId |
PlainShardIterator.shardId() |
ShardId |
IndexShardRoutingTable.shardId()
Returns the shards id
|
ShardId |
ImmutableShardRouting.shardId() |
Modifier and Type | Method and Description |
---|---|
Iterable<ShardId> |
RoutingNodes.getShardsToClearPostAllocationFlag() |
Modifier and Type | Method and Description |
---|---|
void |
RoutingNodes.addClearPostAllocationFlag(ShardId shardId)
Clears the post allocation flag for the provided shard id.
|
IndexRoutingTable.Builder |
IndexRoutingTable.Builder.clearPostAllocationFlag(ShardId shardId)
Clears the post allocation flag for the specified shard
|
Constructor and Description |
---|
Builder(ShardId shardId,
boolean primaryAllocatedPostApi) |
PlainShardIterator(ShardId shardId,
List<ShardRouting> shards)
Creates a
PlainShardIterator instance that iterates over a subset of the given shards
this the a given shardId . |
Modifier and Type | Method and Description |
---|---|
Map<ShardId,List<AllocationExplanation.NodeExplanation>> |
AllocationExplanation.explanations()
List of explanations involved by this AllocationExplanation
|
Modifier and Type | Method and Description |
---|---|
AllocationExplanation |
AllocationExplanation.add(ShardId shardId,
AllocationExplanation.NodeExplanation nodeExplanation)
Create and add a node explanation to this explanation referencing a shard
|
void |
RoutingAllocation.addIgnoreShardForNode(ShardId shardId,
String nodeId) |
boolean |
RoutingAllocation.shouldIgnoreShardForNode(ShardId shardId,
String nodeId) |
Modifier and Type | Method and Description |
---|---|
ShardId |
AllocateAllocationCommand.shardId()
Get the shards id
|
ShardId |
CancelAllocationCommand.shardId()
Get the id of the shard which allocation should be canceled
|
ShardId |
MoveAllocationCommand.shardId() |
Constructor and Description |
---|
AllocateAllocationCommand(ShardId shardId,
String node,
boolean allowPrimary)
Create a new
AllocateAllocationCommand |
CancelAllocationCommand(ShardId shardId,
String node,
boolean allowPrimary)
Creates a new
CancelAllocationCommand |
MoveAllocationCommand(ShardId shardId,
String fromNode,
String toNode) |
Modifier and Type | Method and Description |
---|---|
static ESLogger |
Loggers.getLogger(Class clazz,
Settings settings,
ShardId shardId,
String... prefixes) |
static ESLogger |
Loggers.getLogger(String loggerName,
Settings settings,
ShardId shardId,
String... prefixes)
Just like
Loggers.getLogger(Class,Settings,ShardId,String...) but String loggerName instead of Class. |
Modifier and Type | Method and Description |
---|---|
ShardId |
ShardLock.getShardId()
Returns the locks shards Id.
|
Modifier and Type | Method and Description |
---|---|
Set<ShardId> |
NodeEnvironment.findAllShardIds()
Tries to find all allocated shards for all indices iff the given index on the current node.
|
Set<ShardId> |
NodeEnvironment.findAllShardIds(Index index)
Tries to find all allocated shards for the given index or for all indices iff the given index is
null
on the current node. |
Set<ShardId> |
NodeEnvironment.lockedShards()
Returns all currently lock shards
|
Modifier and Type | Method and Description |
---|---|
void |
NodeEnvironment.deleteShardDirectorySafe(ShardId shardId,
Settings indexSettings)
Deletes a shard data directory iff the shards locks were successfully acquired.
|
Path |
NodeEnvironment.resolveCustomLocation(Settings indexSettings,
ShardId shardId)
Resolve the custom path for a index's shard.
|
File[] |
NodeEnvironment.shardDataLocations(ShardId shardId,
Settings settings)
Deprecated.
use
shardDataPaths instead |
Path[] |
NodeEnvironment.shardDataPaths(ShardId shardId,
Settings indexSettings)
Returns all paths where lucene data will be stored, if a index.data_path
setting is present, will return the custom data path to be used
|
File[] |
NodeEnvironment.shardLocations(ShardId shardId)
Deprecated.
|
ShardLock |
NodeEnvironment.shardLock(ShardId id)
Tries to lock the given shards ID.
|
ShardLock |
NodeEnvironment.shardLock(ShardId id,
long lockTimeoutMS)
Tries to lock the given shards ID.
|
Path[] |
NodeEnvironment.shardPaths(ShardId shardId)
Returns all shard paths excluding custom shard path
|
Constructor and Description |
---|
ShardLock(ShardId id) |
Modifier and Type | Method and Description |
---|---|
ActionFuture<TransportNodesListGatewayStartedShards.NodesLocalGatewayStartedShards> |
TransportNodesListGatewayStartedShards.list(ShardId shardId,
String[] nodesIds,
TimeValue timeout) |
ShardStateInfo |
LocalGatewayShardsState.loadShardInfo(ShardId shardId) |
Constructor and Description |
---|
IndexShardMissingException(ShardId shardId) |
Constructor and Description |
---|
ShardFilterCache(ShardId shardId,
Settings indexSettings) |
Constructor and Description |
---|
ShardFixedBitSetFilterCache(ShardId shardId,
Settings indexSettings) |
Value(org.apache.lucene.util.FixedBitSet fixedBitSet,
ShardId shardId) |
Constructor and Description |
---|
ShardQueryCache(ShardId shardId,
Settings indexSettings) |
Constructor and Description |
---|
KeepLastNDeletionPolicy(ShardId shardId,
Settings indexSettings) |
KeepOnlyLastDeletionPolicy(ShardId shardId,
Settings indexSettings) |
Modifier and Type | Field and Description |
---|---|
protected ShardId |
Engine.shardId |
Modifier and Type | Method and Description |
---|---|
ShardId |
EngineConfig.getShardId()
Returns the engines shard ID
|
Modifier and Type | Method and Description |
---|---|
void |
Engine.FailedEngineListener.onFailedEngine(ShardId shardId,
String reason,
Throwable t) |
Constructor and Description |
---|
ShardFieldData(ShardId shardId,
Settings indexSettings) |
Constructor and Description |
---|
IgnoreGatewayRecoveryException(ShardId shardId,
String msg) |
IgnoreGatewayRecoveryException(ShardId shardId,
String msg,
Throwable cause) |
IndexShardGatewayException(ShardId shardId,
String msg) |
IndexShardGatewayException(ShardId shardId,
String msg,
Throwable cause) |
IndexShardGatewayRecoveryException(ShardId shardId,
String msg) |
IndexShardGatewayRecoveryException(ShardId shardId,
String msg,
Throwable cause) |
IndexShardGatewayService(ShardId shardId,
Settings indexSettings,
ThreadPool threadPool,
IndexShard indexShard,
IndexShardGateway shardGateway,
IndexShardSnapshotAndRestoreService snapshotService,
ClusterService clusterService) |
IndexShardGatewaySnapshotFailedException(ShardId shardId,
String msg,
Throwable cause) |
IndexShardGatewaySnapshotNotAllowedException(ShardId shardId,
String msg) |
Constructor and Description |
---|
LocalIndexShardGateway(ShardId shardId,
Settings indexSettings,
ThreadPool threadPool,
MappingUpdatedAction mappingUpdatedAction,
IndexService indexService,
IndexShard indexShard) |
Constructor and Description |
---|
NoneIndexShardGateway(ShardId shardId,
Settings indexSettings,
IndexShard indexShard) |
Constructor and Description |
---|
ShardGetService(ShardId shardId,
Settings indexSettings,
ScriptService scriptService,
MapperService mapperService,
IndexFieldDataService fieldDataService) |
Constructor and Description |
---|
ShardIndexingService(ShardId shardId,
Settings indexSettings,
ShardSlowLogIndexingService slowLog) |
Constructor and Description |
---|
ShardSlowLogIndexingService(ShardId shardId,
Settings indexSettings,
IndexSettingsService indexSettingsService) |
Constructor and Description |
---|
ConcurrentMergeSchedulerProvider(ShardId shardId,
Settings indexSettings,
ThreadPool threadPool,
IndexSettingsService indexSettingsService) |
MergeSchedulerProvider(ShardId shardId,
Settings indexSettings,
ThreadPool threadPool) |
SerialMergeSchedulerProvider(ShardId shardId,
Settings indexSettings,
ThreadPool threadPool)
Deprecated.
|
Constructor and Description |
---|
PercolatorQueriesRegistry(ShardId shardId,
Settings indexSettings,
IndexQueryParserService queryParserService,
ShardIndexingService indexingService,
IndicesLifecycle indicesLifecycle,
MapperService mapperService,
IndexCache indexCache,
IndexFieldDataService indexFieldDataService,
ShardPercolateService shardPercolateService) |
Constructor and Description |
---|
ShardPercolateService(ShardId shardId,
Settings indexSettings) |
Constructor and Description |
---|
ShardSlowLogSearchService(ShardId shardId,
Settings indexSettings,
IndexSettingsService indexSettingsService) |
Constructor and Description |
---|
ShardSearchService(ShardId shardId,
Settings indexSettings,
ShardSlowLogSearchService slowLogSearchService) |
Modifier and Type | Field and Description |
---|---|
protected ShardId |
AbstractIndexShardComponent.shardId |
Modifier and Type | Method and Description |
---|---|
static ShardId |
ShardUtils.extractShardId(org.apache.lucene.index.AtomicReader reader)
Tries to extract the shard id from a reader if possible, when its not possible,
will return null.
|
static ShardId |
ShardUtils.extractShardId(org.apache.lucene.index.IndexReader reader) |
static ShardId |
ShardId.readShardId(StreamInput in) |
ShardId |
IndexShardException.shardId() |
ShardId |
IndexShardComponent.shardId() |
ShardId |
AbstractIndexShardComponent.shardId() |
Modifier and Type | Method and Description |
---|---|
int |
ShardId.compareTo(ShardId o) |
Modifier and Type | Method and Description |
---|---|
void |
IndexShardRepository.restore(SnapshotId snapshotId,
ShardId shardId,
ShardId snapshotShardId,
RecoveryState recoveryState)
Restores snapshot of the shard.
|
void |
IndexShardRepository.snapshot(SnapshotId snapshotId,
ShardId shardId,
SnapshotIndexCommit snapshotIndexCommit,
IndexShardSnapshotStatus snapshotStatus)
Creates a snapshot of the shard based on the index commit point.
|
IndexShardSnapshotStatus |
IndexShardRepository.snapshotStatus(SnapshotId snapshotId,
ShardId shardId)
Retrieve shard snapshot status for the stored snapshot
|
Constructor and Description |
---|
IndexShardRestoreException(ShardId shardId,
String msg) |
IndexShardRestoreException(ShardId shardId,
String msg,
Throwable cause) |
IndexShardRestoreFailedException(ShardId shardId,
String msg) |
IndexShardRestoreFailedException(ShardId shardId,
String msg,
Throwable cause) |
IndexShardSnapshotAndRestoreService(ShardId shardId,
Settings indexSettings,
IndexShard indexShard,
RepositoriesService repositoriesService,
RestoreService restoreService) |
IndexShardSnapshotException(ShardId shardId,
String msg) |
IndexShardSnapshotException(ShardId shardId,
String msg,
Throwable cause) |
IndexShardSnapshotFailedException(ShardId shardId,
String msg) |
IndexShardSnapshotFailedException(ShardId shardId,
String msg,
Throwable cause) |
Modifier and Type | Method and Description |
---|---|
void |
BlobStoreIndexShardRepository.delete(SnapshotId snapshotId,
ShardId shardId)
Delete shard snapshot
|
void |
BlobStoreIndexShardRepository.restore(SnapshotId snapshotId,
ShardId shardId,
ShardId snapshotShardId,
RecoveryState recoveryState)
Restores snapshot of the shard.
|
void |
BlobStoreIndexShardRepository.snapshot(SnapshotId snapshotId,
ShardId shardId,
SnapshotIndexCommit snapshotIndexCommit,
IndexShardSnapshotStatus snapshotStatus)
Creates a snapshot of the shard based on the index commit point.
|
IndexShardSnapshotStatus |
BlobStoreIndexShardRepository.snapshotStatus(SnapshotId snapshotId,
ShardId shardId)
Retrieve shard snapshot status for the stored snapshot
|
Modifier and Type | Method and Description |
---|---|
ShardId |
Store.StoreDirectory.shardId() |
Modifier and Type | Method and Description |
---|---|
Path[] |
IndexStore.shardIndexLocations(ShardId shardId)
Return an array of all index folder locations for a given shard
|
Path[] |
IndexStore.shardTranslogLocations(ShardId shardId)
Return an array of all translog folder locations for a given shard
|
Constructor and Description |
---|
DirectoryService(ShardId shardId,
Settings indexSettings) |
Store(ShardId shardId,
Settings indexSettings,
DirectoryService directoryService,
Distributor distributor,
ShardLock shardLock) |
Store(ShardId shardId,
Settings indexSettings,
DirectoryService directoryService,
Distributor distributor,
ShardLock shardLock,
Store.OnClose onClose) |
StoreException(ShardId shardId,
String msg) |
StoreException(ShardId shardId,
String msg,
Throwable cause) |
Constructor and Description |
---|
DefaultFsDirectoryService(ShardId shardId,
Settings indexSettings,
IndexStore indexStore) |
FsDirectoryService(ShardId shardId,
Settings indexSettings,
IndexStore indexStore) |
MmapFsDirectoryService(ShardId shardId,
Settings indexSettings,
IndexStore indexStore) |
NioFsDirectoryService(ShardId shardId,
Settings indexSettings,
IndexStore indexStore) |
SimpleFsDirectoryService(ShardId shardId,
Settings indexSettings,
IndexStore indexStore) |
Constructor and Description |
---|
RamDirectoryService(ShardId shardId,
Settings indexSettings) |
Modifier and Type | Method and Description |
---|---|
Path[] |
AbstractIndexStore.shardIndexLocations(ShardId shardId)
Return an array of all index folder locations for a given shard.
|
Path[] |
AbstractIndexStore.shardTranslogLocations(ShardId shardId)
Return an array of all translog folder locations for a given shard.
|
Constructor and Description |
---|
ShardSuggestService(ShardId shardId,
Settings indexSettings) |
Constructor and Description |
---|
ShardTermVectorService(ShardId shardId,
Settings indexSettings,
MappingUpdatedAction mappingUpdatedAction) |
Constructor and Description |
---|
TranslogException(ShardId shardId,
String msg) |
TranslogException(ShardId shardId,
String msg,
Throwable cause) |
TranslogService(ShardId shardId,
Settings indexSettings,
IndexSettingsService indexSettingsService,
ThreadPool threadPool,
IndexShard indexShard,
Translog translog) |
Modifier and Type | Method and Description |
---|---|
abstract FsTranslogFile |
FsTranslogFile.Type.create(ShardId shardId,
long id,
RafReference raf,
int bufferSize) |
Constructor and Description |
---|
BufferingFsTranslogFile(ShardId shardId,
long id,
RafReference raf,
int bufferSize) |
FsTranslog(ShardId shardId,
Settings indexSettings,
File location) |
FsTranslog(ShardId shardId,
Settings indexSettings,
IndexSettingsService indexSettingsService,
BigArrays bigArrays,
IndexStore indexStore) |
SimpleFsTranslogFile(ShardId shardId,
long id,
RafReference raf) |
Constructor and Description |
---|
ShardIndexWarmerService(ShardId shardId,
Settings indexSettings) |
Modifier and Type | Method and Description |
---|---|
ShardId |
IndicesWarmer.WarmerContext.shardId() |
Modifier and Type | Method and Description |
---|---|
void |
IndicesService.addPendingDelete(ShardId shardId,
Settings settings)
Adds a pending delete for the given index shard.
|
void |
InternalIndicesLifecycle.afterIndexShardClosed(ShardId shardId,
IndexShard indexShard,
Settings indexSettings) |
void |
IndicesLifecycle.Listener.afterIndexShardClosed(ShardId shardId,
IndexShard indexShard,
Settings indexSettings)
Called after the index shard has been closed.
|
void |
InternalIndicesLifecycle.afterIndexShardDeleted(ShardId shardId,
Settings indexSettings) |
void |
IndicesLifecycle.Listener.afterIndexShardDeleted(ShardId shardId,
Settings indexSettings)
Called after the index shard has been deleted from disk.
|
void |
InternalIndicesLifecycle.beforeIndexShardClosed(ShardId shardId,
IndexShard indexShard,
Settings indexSettings) |
void |
IndicesLifecycle.Listener.beforeIndexShardClosed(ShardId shardId,
IndexShard indexShard,
Settings indexSettings)
Called before the index shard gets closed.
|
void |
InternalIndicesLifecycle.beforeIndexShardCreated(ShardId shardId,
Settings indexSettings) |
void |
IndicesLifecycle.Listener.beforeIndexShardCreated(ShardId shardId,
Settings indexSettings)
Called before the index shard gets created.
|
void |
InternalIndicesLifecycle.beforeIndexShardDeleted(ShardId shardId,
Settings indexSettings) |
void |
IndicesLifecycle.Listener.beforeIndexShardDeleted(ShardId shardId,
Settings indexSettings)
Called before the index shard gets deleted from disk
Note: this method is only executed on the first attempt of deleting the shard.
|
boolean |
IndicesService.canDeleteShardContent(ShardId shardId,
IndexMetaData metaData)
Returns
true iff the shards content for the given shard can be deleted. |
void |
IndicesService.deleteShardStore(String reason,
ShardId shardId,
IndexMetaData metaData)
This method deletes the shard contents on disk for the given shard ID.
|
Constructor and Description |
---|
WarmerContext(ShardId shardId,
Engine.Searcher searcher) |
Modifier and Type | Method and Description |
---|---|
ShardId |
RecoveryState.getShardId() |
ShardId |
RecoveryStatus.shardId() |
ShardId |
RecoveryFileChunkRequest.shardId() |
ShardId |
StartRecoveryRequest.shardId() |
Modifier and Type | Method and Description |
---|---|
void |
RecoveriesCollection.cancelRecoveriesForShard(ShardId shardId,
String reason)
cancel all ongoing recoveries for the given shard.
|
RecoveriesCollection.StatusRef |
RecoveriesCollection.getStatusSafe(long id,
ShardId shardId)
Similar to
RecoveriesCollection.getStatus(long) but throws an exception if no recovery is found |
Constructor and Description |
---|
RecoverFilesRecoveryException(ShardId shardId,
int numberOfFiles,
ByteSizeValue totalFilesSize,
Throwable cause) |
RecoveryFailedException(ShardId shardId,
DiscoveryNode sourceNode,
DiscoveryNode targetNode,
String extraInfo,
Throwable cause) |
RecoveryFailedException(ShardId shardId,
DiscoveryNode sourceNode,
DiscoveryNode targetNode,
Throwable cause) |
RecoveryFileChunkRequest(long recoveryId,
ShardId shardId,
StoreFileMetaData metaData,
long position,
BytesReference content,
boolean lastChunk,
int totalTranslogOps,
long sourceThrottleTimeInNanos) |
RecoveryState(ShardId shardId,
boolean primary,
RecoveryState.Type type,
DiscoveryNode sourceNode,
DiscoveryNode targetNode) |
RecoveryState(ShardId shardId,
boolean primary,
RecoveryState.Type type,
RestoreSource restoreSource,
DiscoveryNode targetNode) |
StartRecoveryRequest(ShardId shardId,
DiscoveryNode sourceNode,
DiscoveryNode targetNode,
boolean markAsRelocated,
Map<String,StoreFileMetaData> existingFiles,
RecoveryState.Type recoveryType,
long recoveryId)
Start recovery request.
|
Modifier and Type | Method and Description |
---|---|
ShardId |
TransportNodesListShardStoreMetaData.StoreFilesMetaData.shardId() |
Modifier and Type | Method and Description |
---|---|
ActionFuture<TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData> |
TransportNodesListShardStoreMetaData.list(ShardId shardId,
boolean onlyUnallocated,
String[] nodesIds,
TimeValue timeout) |
Constructor and Description |
---|
StoreFilesMetaData(boolean allocated,
ShardId shardId,
Map<String,StoreFileMetaData> files) |
Modifier and Type | Method and Description |
---|---|
ShardId |
PercolateException.getShardId() |
Constructor and Description |
---|
PercolateException(ShardId shardId,
String msg,
Throwable cause) |
PercolateException(String msg,
ShardId shardId) |
Constructor and Description |
---|
ShardSearchLocalRequest(ShardId shardId,
int numberOfShards,
SearchType searchType,
BytesReference source,
String[] types,
Boolean queryCache) |
Modifier and Type | Method and Description |
---|---|
com.google.common.collect.ImmutableMap<ShardId,IndexShardSnapshotStatus> |
SnapshotsService.currentSnapshotShards(SnapshotId snapshotId)
Returns status of shards that are snapshotted on the node and belong to the given snapshot
|
com.google.common.collect.ImmutableMap<ShardId,IndexShardSnapshotStatus> |
SnapshotsService.snapshotShards(SnapshotId snapshotId)
Returns status of shards currently finished snapshots
|
Modifier and Type | Method and Description |
---|---|
void |
RestoreService.failRestore(SnapshotId snapshotId,
ShardId shardId)
Fails the given snapshot restore operation for the given shard
|
void |
RestoreService.indexShardRestoreCompleted(SnapshotId snapshotId,
ShardId shardId)
This method is used by
IndexShardSnapshotAndRestoreService to notify
RestoreService about shard restore completion. |
Copyright © 2009–2015. All rights reserved.