Uses of Class
org.elasticsearch.index.shard.ShardId

Packages that use ShardId
org.elasticsearch.action   
org.elasticsearch.action.admin.indices.segments   
org.elasticsearch.action.admin.indices.stats   
org.elasticsearch.action.admin.indices.status   
org.elasticsearch.action.bulk   
org.elasticsearch.action.support.broadcast   
org.elasticsearch.action.support.replication   
org.elasticsearch.cluster.routing   
org.elasticsearch.cluster.routing.allocation   
org.elasticsearch.common.logging   
org.elasticsearch.env   
org.elasticsearch.gateway.local.state.shards   
org.elasticsearch.index   
org.elasticsearch.index.deletionpolicy   
org.elasticsearch.index.engine   
org.elasticsearch.index.engine.robin   
org.elasticsearch.index.gateway   
org.elasticsearch.index.gateway.blobstore   
org.elasticsearch.index.gateway.fs   
org.elasticsearch.index.gateway.local   
org.elasticsearch.index.gateway.none   
org.elasticsearch.index.get   
org.elasticsearch.index.indexing   
org.elasticsearch.index.merge.scheduler   
org.elasticsearch.index.search.slowlog   
org.elasticsearch.index.search.stats   
org.elasticsearch.index.shard   
org.elasticsearch.index.shard.service   
org.elasticsearch.index.store   
org.elasticsearch.index.store.fs   
org.elasticsearch.index.store.memory   
org.elasticsearch.index.store.ram   
org.elasticsearch.index.store.support   
org.elasticsearch.index.translog   
org.elasticsearch.index.translog.fs   
org.elasticsearch.index.warmer   
org.elasticsearch.indices   
org.elasticsearch.indices.recovery   
org.elasticsearch.indices.store   
org.elasticsearch.indices.warmer   
org.elasticsearch.search   
 

Uses of ShardId in org.elasticsearch.action
 

Constructors in org.elasticsearch.action with parameters of type ShardId
NoShardAvailableActionException(ShardId shardId, String msg)
           
NoShardAvailableActionException(ShardId shardId, String msg, Throwable cause)
           
UnavailableShardsException(ShardId shardId, String message)
           
 

Uses of ShardId in org.elasticsearch.action.admin.indices.segments
 

Methods in org.elasticsearch.action.admin.indices.segments that return ShardId
 ShardId IndexShardSegments.getShardId()
           
 ShardId IndexShardSegments.shardId()
           
 

Uses of ShardId in org.elasticsearch.action.admin.indices.stats
 

Methods in org.elasticsearch.action.admin.indices.stats that return ShardId
 ShardId IndexShardStats.getShardId()
           
 ShardId IndexShardStats.shardId()
           
 

Uses of ShardId in org.elasticsearch.action.admin.indices.status
 

Methods in org.elasticsearch.action.admin.indices.status that return ShardId
 ShardId IndexShardStatus.getShardId()
           
 ShardId IndexShardStatus.shardId()
           
 

Uses of ShardId in org.elasticsearch.action.bulk
 

Methods in org.elasticsearch.action.bulk that return ShardId
 ShardId BulkShardResponse.shardId()
           
 

Uses of ShardId in org.elasticsearch.action.support.broadcast
 

Constructors in org.elasticsearch.action.support.broadcast with parameters of type ShardId
BroadcastShardOperationFailedException(ShardId shardId, String msg)
           
BroadcastShardOperationFailedException(ShardId shardId, String msg, Throwable cause)
           
BroadcastShardOperationFailedException(ShardId shardId, Throwable cause)
           
 

Uses of ShardId in org.elasticsearch.action.support.replication
 

Constructors in org.elasticsearch.action.support.replication with parameters of type ShardId
ReplicationShardOperationFailedException(ShardId shardId, String msg)
           
ReplicationShardOperationFailedException(ShardId shardId, String msg, Throwable cause)
           
ReplicationShardOperationFailedException(ShardId shardId, Throwable cause)
           
 

Uses of ShardId in org.elasticsearch.cluster.routing
 

Methods in org.elasticsearch.cluster.routing that return ShardId
 ShardId IndexShardRoutingTable.getShardId()
           
 ShardId PlainShardIterator.shardId()
           
 ShardId ImmutableShardRouting.shardId()
           
 ShardId ShardRouting.shardId()
          The shard id.
 ShardId IndexShardRoutingTable.shardId()
           
 ShardId ShardIterator.shardId()
          The shard id this group relates to.
 

Constructors in org.elasticsearch.cluster.routing with parameters of type ShardId
IndexShardRoutingTable.Builder(ShardId shardId, boolean allocatedPostApi)
           
PlainShardIterator(ShardId shardId, List<ShardRouting> shards)
           
PlainShardIterator(ShardId shardId, List<ShardRouting> shards, int index)
           
 

Uses of ShardId in org.elasticsearch.cluster.routing.allocation
 

Methods in org.elasticsearch.cluster.routing.allocation that return types with arguments of type ShardId
 Map<ShardId,List<AllocationExplanation.NodeExplanation>> AllocationExplanation.explanations()
           
 

Methods in org.elasticsearch.cluster.routing.allocation with parameters of type ShardId
 AllocationExplanation AllocationExplanation.add(ShardId shardId, AllocationExplanation.NodeExplanation nodeExplanation)
           
 void RoutingAllocation.addIgnoreShardForNode(ShardId shardId, String nodeId)
           
 boolean RoutingAllocation.shouldIgnoreShardForNode(ShardId shardId, String nodeId)
           
 

Uses of ShardId in org.elasticsearch.common.logging
 

Methods in org.elasticsearch.common.logging with parameters of type ShardId
static ESLogger Loggers.getLogger(Class clazz, Settings settings, ShardId shardId, String... prefixes)
           
 

Uses of ShardId in org.elasticsearch.env
 

Methods in org.elasticsearch.env that return types with arguments of type ShardId
 Set<ShardId> NodeEnvironment.findAllShardIds()
           
 

Methods in org.elasticsearch.env with parameters of type ShardId
 File[] NodeEnvironment.shardLocations(ShardId shardId)
           
 

Uses of ShardId in org.elasticsearch.gateway.local.state.shards
 

Methods in org.elasticsearch.gateway.local.state.shards that return types with arguments of type ShardId
 Map<ShardId,ShardStateInfo> LocalGatewayShardsState.currentStartedShards()
           
 

Methods in org.elasticsearch.gateway.local.state.shards with parameters of type ShardId
 ActionFuture<TransportNodesListGatewayStartedShards.NodesLocalGatewayStartedShards> TransportNodesListGatewayStartedShards.list(ShardId shardId, Set<String> nodesIds, TimeValue timeout)
           
 ShardStateInfo LocalGatewayShardsState.loadShardInfo(ShardId shardId)
           
 

Uses of ShardId in org.elasticsearch.index
 

Constructors in org.elasticsearch.index with parameters of type ShardId
IndexShardMissingException(ShardId shardId)
           
 

Uses of ShardId in org.elasticsearch.index.deletionpolicy
 

Constructors in org.elasticsearch.index.deletionpolicy with parameters of type ShardId
KeepLastNDeletionPolicy(ShardId shardId, Settings indexSettings)
           
KeepOnlyLastDeletionPolicy(ShardId shardId, Settings indexSettings)
           
 

Uses of ShardId in org.elasticsearch.index.engine
 

Methods in org.elasticsearch.index.engine with parameters of type ShardId
 void Engine.FailedEngineListener.onFailedEngine(ShardId shardId, Throwable t)
           
 

Constructors in org.elasticsearch.index.engine with parameters of type ShardId
CloseEngineException(ShardId shardId, String msg)
           
CloseEngineException(ShardId shardId, String msg, Throwable cause)
           
CreateFailedEngineException(ShardId shardId, Engine.Create create, Throwable cause)
           
DeleteByQueryFailedEngineException(ShardId shardId, Engine.DeleteByQuery deleteByQuery, Throwable cause)
           
DeleteFailedEngineException(ShardId shardId, Engine.Delete delete, Throwable cause)
           
DocumentAlreadyExistsException(ShardId shardId, String type, String id)
           
DocumentMissingException(ShardId shardId, String type, String id)
           
DocumentSourceMissingException(ShardId shardId, String type, String id)
           
EngineAlreadyStartedException(ShardId shardId)
           
EngineClosedException(ShardId shardId)
           
EngineClosedException(ShardId shardId, Throwable t)
           
EngineCreationFailureException(ShardId shardId, String msg, Throwable cause)
           
EngineException(ShardId shardId, String msg)
           
EngineException(ShardId shardId, String msg, Throwable cause)
           
FlushFailedEngineException(ShardId shardId, String message, Throwable t)
           
FlushFailedEngineException(ShardId shardId, Throwable t)
           
FlushNotAllowedEngineException(ShardId shardId, String msg)
           
IndexFailedEngineException(ShardId shardId, Engine.Index index, Throwable cause)
           
OptimizeFailedEngineException(ShardId shardId, Throwable t)
           
RecoveryEngineException(ShardId shardId, int phase, String msg, Throwable cause)
           
RefreshFailedEngineException(ShardId shardId, Throwable t)
           
RollbackFailedEngineException(ShardId shardId, Throwable t)
           
RollbackNotAllowedEngineException(ShardId shardId, String msg)
           
SnapshotFailedEngineException(ShardId shardId, Throwable cause)
           
VersionConflictEngineException(ShardId shardId, String type, String id, long current, long provided)
           
 

Uses of ShardId in org.elasticsearch.index.engine.robin
 

Constructors in org.elasticsearch.index.engine.robin with parameters of type ShardId
RobinEngine(ShardId shardId, Settings indexSettings, ThreadPool threadPool, IndexSettingsService indexSettingsService, ShardIndexingService indexingService, IndicesWarmer warmer, Store store, SnapshotDeletionPolicy deletionPolicy, Translog translog, MergePolicyProvider mergePolicyProvider, MergeSchedulerProvider mergeScheduler, AnalysisService analysisService, SimilarityService similarityService, BloomCache bloomCache)
           
 

Uses of ShardId in org.elasticsearch.index.gateway
 

Constructors in org.elasticsearch.index.gateway with parameters of type ShardId
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, IndexSettingsService indexSettingsService, ThreadPool threadPool, IndexShard indexShard, IndexShardGateway shardGateway)
           
IndexShardGatewaySnapshotFailedException(ShardId shardId, String msg, Throwable cause)
           
IndexShardGatewaySnapshotNotAllowedException(ShardId shardId, String msg)
           
 

Uses of ShardId in org.elasticsearch.index.gateway.blobstore
 

Constructors in org.elasticsearch.index.gateway.blobstore with parameters of type ShardId
BlobStoreIndexShardGateway(ShardId shardId, Settings indexSettings, ThreadPool threadPool, IndexGateway indexGateway, IndexShard indexShard, Store store)
           
 

Uses of ShardId in org.elasticsearch.index.gateway.fs
 

Constructors in org.elasticsearch.index.gateway.fs with parameters of type ShardId
FsIndexShardGateway(ShardId shardId, Settings indexSettings, ThreadPool threadPool, IndexGateway fsIndexGateway, IndexShard indexShard, Store store)
           
 

Uses of ShardId in org.elasticsearch.index.gateway.local
 

Constructors in org.elasticsearch.index.gateway.local with parameters of type ShardId
LocalIndexShardGateway(ShardId shardId, Settings indexSettings, ThreadPool threadPool, IndexShard indexShard)
           
 

Uses of ShardId in org.elasticsearch.index.gateway.none
 

Constructors in org.elasticsearch.index.gateway.none with parameters of type ShardId
NoneIndexShardGateway(ShardId shardId, Settings indexSettings, IndexShard indexShard)
           
 

Uses of ShardId in org.elasticsearch.index.get
 

Constructors in org.elasticsearch.index.get with parameters of type ShardId
ShardGetService(ShardId shardId, Settings indexSettings, ScriptService scriptService, MapperService mapperService, IndexCache indexCache)
           
 

Uses of ShardId in org.elasticsearch.index.indexing
 

Constructors in org.elasticsearch.index.indexing with parameters of type ShardId
ShardIndexingService(ShardId shardId, Settings indexSettings)
           
 

Uses of ShardId in org.elasticsearch.index.merge.scheduler
 

Constructors in org.elasticsearch.index.merge.scheduler with parameters of type ShardId
ConcurrentMergeSchedulerProvider(ShardId shardId, Settings indexSettings)
           
SerialMergeSchedulerProvider(ShardId shardId, Settings indexSettings)
           
 

Uses of ShardId in org.elasticsearch.index.search.slowlog
 

Constructors in org.elasticsearch.index.search.slowlog with parameters of type ShardId
ShardSlowLogSearchService(ShardId shardId, Settings indexSettings, IndexSettingsService indexSettingsService)
           
 

Uses of ShardId in org.elasticsearch.index.search.stats
 

Constructors in org.elasticsearch.index.search.stats with parameters of type ShardId
ShardSearchService(ShardId shardId, Settings indexSettings, ShardSlowLogSearchService slowLogSearchService)
           
 

Uses of ShardId in org.elasticsearch.index.shard
 

Fields in org.elasticsearch.index.shard declared as ShardId
protected  ShardId AbstractIndexShardComponent.shardId
           
 

Methods in org.elasticsearch.index.shard that return ShardId
static ShardId ShardId.readShardId(StreamInput in)
           
 ShardId IndexShardException.shardId()
           
 ShardId AbstractIndexShardComponent.shardId()
           
 ShardId IndexShardComponent.shardId()
           
 

Methods in org.elasticsearch.index.shard with parameters of type ShardId
static String IndexShardManagement.buildShardGroupName(ShardId shardId)
           
 

Constructors in org.elasticsearch.index.shard with parameters of type ShardId
AbstractIndexShardComponent(ShardId shardId, Settings indexSettings)
           
AbstractIndexShardComponent(ShardId shardId, Settings indexSettings, String prefixSettings)
           
IllegalIndexShardStateException(ShardId shardId, IndexShardState currentState, String msg)
           
IllegalIndexShardStateException(ShardId shardId, IndexShardState currentState, String msg, Throwable ex)
           
IndexShardClosedException(ShardId shardId)
           
IndexShardClosedException(ShardId shardId, Throwable t)
           
IndexShardCreationException(ShardId shardId, Throwable cause)
           
IndexShardException(ShardId shardId, String msg)
           
IndexShardException(ShardId shardId, String msg, Throwable cause)
           
IndexShardManagement(ShardId shardId, Settings indexSettings, JmxService jmxService, IndexShard indexShard, Store store, Translog translog)
           
IndexShardModule(Settings settings, ShardId shardId)
           
IndexShardNotRecoveringException(ShardId shardId, IndexShardState currentState)
           
IndexShardNotStartedException(ShardId shardId, IndexShardState currentState)
           
IndexShardRecoveringException(ShardId shardId)
           
IndexShardRelocatedException(ShardId shardId)
           
IndexShardStartedException(ShardId shardId)
           
 

Uses of ShardId in org.elasticsearch.index.shard.service
 

Constructors in org.elasticsearch.index.shard.service with parameters of type ShardId
InternalIndexShard(ShardId shardId, Settings indexSettings, IndexSettingsService indexSettingsService, IndicesLifecycle indicesLifecycle, Store store, Engine engine, MergeSchedulerProvider mergeScheduler, Translog translog, ThreadPool threadPool, MapperService mapperService, IndexQueryParserService queryParserService, IndexCache indexCache, IndexAliasesService indexAliasesService, ShardIndexingService indexingService, ShardGetService getService, ShardSearchService searchService, ShardIndexWarmerService shardWarmerService)
           
 

Uses of ShardId in org.elasticsearch.index.store
 

Methods in org.elasticsearch.index.store with parameters of type ShardId
 boolean IndexStore.canDeleteUnallocated(ShardId shardId)
          Returns true if this shard is allocated on this node.
 void IndexStore.deleteUnallocated(ShardId shardId)
          Deletes this shard store since its no longer allocated.
 

Constructors in org.elasticsearch.index.store with parameters of type ShardId
Store(ShardId shardId, Settings indexSettings, IndexStore indexStore, IndexSettingsService indexSettingsService, DirectoryService directoryService)
           
StoreException(ShardId shardId, String msg)
           
StoreException(ShardId shardId, String msg, Throwable cause)
           
 

Uses of ShardId in org.elasticsearch.index.store.fs
 

Methods in org.elasticsearch.index.store.fs with parameters of type ShardId
 boolean FsIndexStore.canDeleteUnallocated(ShardId shardId)
           
 void FsIndexStore.deleteUnallocated(ShardId shardId)
           
 File[] FsIndexStore.shardIndexLocations(ShardId shardId)
           
 File[] FsIndexStore.shardLocations(ShardId shardId)
           
 File[] FsIndexStore.shardTranslogLocations(ShardId shardId)
           
 

Constructors in org.elasticsearch.index.store.fs with parameters of type ShardId
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)
           
 

Uses of ShardId in org.elasticsearch.index.store.memory
 

Constructors in org.elasticsearch.index.store.memory with parameters of type ShardId
ByteBufferDirectoryService(ShardId shardId, Settings indexSettings, IndexStore indexStore, ByteBufferCache byteBufferCache)
           
 

Uses of ShardId in org.elasticsearch.index.store.ram
 

Constructors in org.elasticsearch.index.store.ram with parameters of type ShardId
RamDirectoryService(ShardId shardId, Settings indexSettings)
           
 

Uses of ShardId in org.elasticsearch.index.store.support
 

Methods in org.elasticsearch.index.store.support with parameters of type ShardId
 boolean AbstractIndexStore.canDeleteUnallocated(ShardId shardId)
           
 void AbstractIndexStore.deleteUnallocated(ShardId shardId)
           
 

Uses of ShardId in org.elasticsearch.index.translog
 

Constructors in org.elasticsearch.index.translog with parameters of type ShardId
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)
           
 

Uses of ShardId in org.elasticsearch.index.translog.fs
 

Methods in org.elasticsearch.index.translog.fs with parameters of type ShardId
abstract  FsTranslogFile FsTranslogFile.Type.create(ShardId shardId, long id, RafReference raf, int bufferSize)
           
 

Constructors in org.elasticsearch.index.translog.fs with parameters of type ShardId
BufferingFsTranslogFile(ShardId shardId, long id, RafReference raf, int bufferSize)
           
FsTranslog(ShardId shardId, Settings indexSettings, File location)
           
FsTranslog(ShardId shardId, Settings indexSettings, IndexSettingsService indexSettingsService, NodeEnvironment nodeEnv)
           
SimpleFsTranslogFile(ShardId shardId, long id, RafReference raf)
           
 

Uses of ShardId in org.elasticsearch.index.warmer
 

Constructors in org.elasticsearch.index.warmer with parameters of type ShardId
ShardIndexWarmerService(ShardId shardId, Settings indexSettings)
           
 

Uses of ShardId in org.elasticsearch.indices
 

Methods in org.elasticsearch.indices with parameters of type ShardId
 void IndicesLifecycle.Listener.afterIndexShardClosed(ShardId shardId, boolean delete)
          Called after the index shard has been closed.
 void InternalIndicesLifecycle.afterIndexShardClosed(ShardId shardId, boolean delete)
           
 void IndicesLifecycle.Listener.beforeIndexShardClosed(ShardId shardId, IndexShard indexShard, boolean delete)
          Called before the index shard gets closed.
 void InternalIndicesLifecycle.beforeIndexShardClosed(ShardId shardId, IndexShard indexShard, boolean delete)
           
 void IndicesLifecycle.Listener.beforeIndexShardCreated(ShardId shardId)
          Called before the index shard gets created.
 void InternalIndicesLifecycle.beforeIndexShardCreated(ShardId shardId)
           
 

Uses of ShardId in org.elasticsearch.indices.recovery
 

Methods in org.elasticsearch.indices.recovery that return ShardId
 ShardId StartRecoveryRequest.shardId()
           
 

Methods in org.elasticsearch.indices.recovery with parameters of type ShardId
 RecoveryStatus RecoveryTarget.peerRecoveryStatus(ShardId shardId)
           
 

Constructors in org.elasticsearch.indices.recovery with parameters of type ShardId
RecoverFilesRecoveryException(ShardId shardId, int numberOfFiles, ByteSizeValue totalFilesSize, Throwable cause)
           
RecoveryFailedException(ShardId shardId, DiscoveryNode sourceNode, DiscoveryNode targetNode, Throwable cause)
           
StartRecoveryRequest(ShardId shardId, DiscoveryNode sourceNode, DiscoveryNode targetNode, boolean markAsRelocated, Map<String,StoreFileMetaData> existingFiles)
          Start recovery request.
 

Uses of ShardId in org.elasticsearch.indices.store
 

Methods in org.elasticsearch.indices.store that return ShardId
 ShardId TransportNodesListShardStoreMetaData.StoreFilesMetaData.shardId()
           
 

Methods in org.elasticsearch.indices.store with parameters of type ShardId
 ActionFuture<TransportNodesListShardStoreMetaData.NodesStoreFilesMetaData> TransportNodesListShardStoreMetaData.list(ShardId shardId, boolean onlyUnallocated, Set<String> nodesIds, TimeValue timeout)
           
 

Constructors in org.elasticsearch.indices.store with parameters of type ShardId
TransportNodesListShardStoreMetaData.StoreFilesMetaData(boolean allocated, ShardId shardId, Map<String,StoreFileMetaData> files)
           
 

Uses of ShardId in org.elasticsearch.indices.warmer
 

Methods in org.elasticsearch.indices.warmer that return ShardId
 ShardId IndicesWarmer.WarmerContext.shardId()
           
 

Constructors in org.elasticsearch.indices.warmer with parameters of type ShardId
IndicesWarmer.WarmerContext(ShardId shardId, Engine.Searcher fullSearcher, Engine.Searcher newSearcher)
           
 

Uses of ShardId in org.elasticsearch.search
 

Methods in org.elasticsearch.search with parameters of type ShardId
 void SearchService.releaseContextsForShard(ShardId shardId)
           
 



Copyright © 2009-2012. All Rights Reserved.