Safe Haskell | None |
---|---|
Language | Haskell2010 |
Database.Bloodhound.Client.Cluster
Synopsis
- data Version = Version {}
- data BulkAction
- data Status = Status {
- name :: Text
- cluster_name :: Text
- cluster_uuid :: Text
- version :: Version
- tagline :: Text
- newtype Mapping = Mapping {}
- newtype Bytes = Bytes Int
- data Interval
- newtype NodeName = NodeName {}
- data HealthStatus = HealthStatus {
- healthStatusClusterName :: Text
- healthStatusStatus :: Text
- healthStatusTimedOut :: Bool
- healthStatusNumberOfNodes :: Int
- healthStatusNumberOfDataNodes :: Int
- healthStatusActivePrimaryShards :: Int
- healthStatusActiveShards :: Int
- healthStatusRelocatingShards :: Int
- healthStatusInitializingShards :: Int
- healthStatusUnassignedShards :: Int
- healthStatusDelayedUnassignedShards :: Int
- healthStatusNumberOfPendingTasks :: Int
- healthStatusNumberOfInFlightFetch :: Int
- healthStatusTaskMaxWaitingInQueueMillis :: Int
- healthStatusActiveShardsPercentAsNumber :: Float
- data IndexedDocument = IndexedDocument {}
- data DeletedDocuments = DeletedDocuments {
- delDocsTook :: Int
- delDocsTimedOut :: Bool
- delDocsTotal :: Int
- delDocsDeleted :: Int
- delDocsBatches :: Int
- delDocsVersionConflicts :: Int
- delDocsNoops :: Int
- delDocsRetries :: DeletedDocumentsRetries
- delDocsThrottledMillis :: Int
- delDocsRequestsPerSecond :: Float
- delDocsThrottledUntilMillis :: Int
- delDocsFailures :: [Value]
- data DeletedDocumentsRetries = DeletedDocumentsRetries {}
- data BulkOperation
- = BulkIndex IndexName DocId Value
- | BulkIndexAuto IndexName Value
- | BulkIndexEncodingAuto IndexName Encoding
- | BulkCreate IndexName DocId Value
- | BulkCreateEncoding IndexName DocId Encoding
- | BulkDelete IndexName DocId
- | BulkUpdate IndexName DocId Value
- | BulkUpsert IndexName DocId UpsertPayload [UpsertActionMetadata]
- data UpsertActionMetadata
- data UpsertPayload
- buildUpsertActionMetadata :: UpsertActionMetadata -> Pair
- data BulkResponse = BulkResponse {
- bulkTook :: Int
- bulkErrors :: Bool
- bulkActionItems :: [BulkActionItem]
- data BulkActionItem = BulkActionItem {}
- data BulkItem = BulkItem {}
- data BulkError = BulkError {}
- bulkTookLens :: Lens' BulkResponse Int
- bulkErrorsLens :: Lens' BulkResponse Bool
- bulkActionItemsLens :: Lens' BulkResponse [BulkActionItem]
- baiActionLens :: Lens' BulkActionItem BulkAction
- baiItemLens :: Lens' BulkActionItem BulkItem
- biIndexLens :: Lens' BulkItem Text
- biIdLens :: Lens' BulkItem Text
- biStatusLens :: Lens' BulkItem (Maybe Int)
- biErrorLens :: Lens' BulkItem (Maybe BulkError)
- beTypeLens :: Lens' BulkError Text
- beReasonLens :: Lens' BulkError Text
- newtype CountQuery = CountQuery {
- countQuery :: Query
- data CountResponse = CountResponse {}
- data CountShards = CountShards {}
- countResponseCountLens :: Lens' CountResponse Natural
- countResponseShardsLens :: Lens' CountResponse CountShards
- countShardsTotalLens :: Lens' CountShards Int
- countShardsSuccessfulLens :: Lens' CountShards Int
- countShardsFailedLens :: Lens' CountShards Int
- data AliasRouting
- data AllocationPolicy
- data CompoundFormat
- data Compression
- data FSType
- newtype FieldDefinition = FieldDefinition {}
- data FieldType
- data ForceMergeIndexSettings = ForceMergeIndexSettings {}
- data IndexAlias = IndexAlias {}
- data IndexAliasAction
- data IndexAliasCreate = IndexAliasCreate {}
- newtype IndexAliasRouting = IndexAliasRouting RoutingValue
- data IndexAliasSummary = IndexAliasSummary {}
- newtype IndexAliasesSummary = IndexAliasesSummary {}
- data IndexDocumentSettings = IndexDocumentSettings {}
- data IndexMappingsLimits = IndexMappingsLimits {}
- newtype IndexPattern = IndexPattern Text
- data IndexSelection
- data IndexSettings = IndexSettings {}
- data IndexSettingsSummary = IndexSettingsSummary {}
- data IndexTemplate = IndexTemplate {}
- data JoinRelation
- data MappingField = MappingField {}
- newtype NominalDiffTimeJSON = NominalDiffTimeJSON {}
- data OpenCloseIndex
- data ReplicaBounds
- newtype RoutingValue = RoutingValue {
- routingValue :: Text
- newtype SearchAliasRouting = SearchAliasRouting (NonEmpty RoutingValue)
- newtype TemplateName = TemplateName Text
- data UpdatableIndexSetting
- = NumberOfReplicas ReplicaCount
- | AutoExpandReplicas ReplicaBounds
- | BlocksReadOnly Bool
- | BlocksRead Bool
- | BlocksWrite Bool
- | BlocksMetaData Bool
- | RefreshInterval NominalDiffTime
- | IndexConcurrency Int
- | FailOnMergeFailure Bool
- | TranslogFlushThresholdOps Int
- | TranslogFlushThresholdSize Bytes
- | TranslogFlushThresholdPeriod NominalDiffTime
- | TranslogDisableFlush Bool
- | CacheFilterMaxSize (Maybe Bytes)
- | CacheFilterExpire (Maybe NominalDiffTime)
- | GatewaySnapshotInterval NominalDiffTime
- | RoutingAllocationInclude (NonEmpty NodeAttrFilter)
- | RoutingAllocationExclude (NonEmpty NodeAttrFilter)
- | RoutingAllocationRequire (NonEmpty NodeAttrFilter)
- | RoutingAllocationEnable AllocationPolicy
- | RoutingAllocationShardsPerNode ShardCount
- | RecoveryInitialShards InitialShardCount
- | GCDeletes NominalDiffTime
- | TTLDisablePurge Bool
- | TranslogFSType FSType
- | CompressionSetting Compression
- | IndexCompoundFormat CompoundFormat
- | IndexCompoundOnFlush Bool
- | WarmerEnabled Bool
- | MappingTotalFieldsLimit Int
- | AnalysisSetting Analysis
- | UnassignedNodeLeftDelayedTimeout NominalDiffTime
- defaultForceMergeIndexSettings :: ForceMergeIndexSettings
- defaultIndexDocumentSettings :: IndexDocumentSettings
- defaultIndexMappingsLimits :: IndexMappingsLimits
- defaultIndexSettings :: IndexSettings
- statusNameLens :: Lens' Status Text
- statusClusterNameLens :: Lens' Status Text
- statusClusterUuidLens :: Lens' Status Text
- statusVersionLens :: Lens' Status Version
- statusTaglineLens :: Lens' Status Text
- indexSettingsShardsLens :: Lens' IndexSettings ShardCount
- indexSettingsReplicasLens :: Lens' IndexSettings ReplicaCount
- indexSettingsMappingsLimitsLens :: Lens' IndexSettings IndexMappingsLimits
- indexMappingsLimitsDepthLens :: Lens' IndexMappingsLimits (Maybe Int)
- indexMappingsLimitsNestedFieldsLens :: Lens' IndexMappingsLimits (Maybe Int)
- indexMappingsLimitsNestedObjectsLens :: Lens' IndexMappingsLimits (Maybe Int)
- indexMappingsLimitsFieldNameLengthLens :: Lens' IndexMappingsLimits (Maybe Int)
- forceMergeIndexSettingsMaxNumSegmentsLens :: Lens' ForceMergeIndexSettings (Maybe Int)
- forceMergeIndexSettingsOnlyExpungeDeletesLens :: Lens' ForceMergeIndexSettings Bool
- forceMergeIndexSettingsFlushAfterOptimizeLens :: Lens' ForceMergeIndexSettings Bool
- indexSettingsSummarySummaryIndexNameLens :: Lens' IndexSettingsSummary IndexName
- indexSettingsSummarySummaryFixedSettingsLens :: Lens' IndexSettingsSummary IndexSettings
- indexSettingsSummarySummaryUpdateableLens :: Lens' IndexSettingsSummary [UpdatableIndexSetting]
- fieldDefinitionTypeLens :: Lens' FieldDefinition FieldType
- indexTemplatePatternsLens :: Lens' IndexTemplate [IndexPattern]
- indexTemplateSettingsLens :: Lens' IndexTemplate (Maybe IndexSettings)
- indexTemplateMappingsLens :: Lens' IndexTemplate Value
- mappingFieldNameLens :: Lens' MappingField FieldName
- mappingFieldDefinitionLens :: Lens' MappingField FieldDefinition
- mappingFieldsLens :: Lens' Mapping [MappingField]
- indexAliasSrcIndexLens :: Lens' IndexAlias IndexName
- indexAliasLens :: Lens' IndexAlias IndexAliasName
- indexAliasCreateRoutingLens :: Lens' IndexAliasCreate (Maybe AliasRouting)
- indexAliasCreateFilterLens :: Lens' IndexAliasCreate (Maybe Filter)
- routingValueLens :: Lens' RoutingValue Text
- indexAliasesSummaryLens :: Lens' IndexAliasesSummary [IndexAliasSummary]
- indexAliasSummaryAliasLens :: Lens' IndexAliasSummary IndexAlias
- indexAliasSummaryCreateLens :: Lens' IndexAliasSummary IndexAliasCreate
- indexDocumentSettingsVersionControlLens :: Lens' IndexDocumentSettings VersionControl
- indexDocumentSettingsJoinRelationLens :: Lens' IndexDocumentSettings (Maybe JoinRelation)
- data BoundTransportAddress = BoundTransportAddress {}
- newtype BuildHash = BuildHash {}
- data CPUInfo = CPUInfo {
- cpuCacheSize :: Bytes
- cpuCoresPerSocket :: Int
- cpuTotalSockets :: Int
- cpuTotalCores :: Int
- cpuMHZ :: Int
- cpuModel :: Text
- cpuVendor :: Text
- newtype ClusterName = ClusterName {
- clusterName :: Text
- newtype EsAddress = EsAddress {}
- newtype EsPassword = EsPassword {
- esPassword :: Text
- newtype EsUsername = EsUsername {
- esUsername :: Text
- newtype FullNodeId = FullNodeId {
- fullNodeId :: Text
- data InitialShardCount
- data JVMBufferPoolStats = JVMBufferPoolStats {}
- newtype JVMGCCollector = JVMGCCollector {}
- data JVMGCStats = JVMGCStats {}
- data JVMMemoryInfo = JVMMemoryInfo {}
- newtype JVMMemoryPool = JVMMemoryPool {}
- data JVMPoolStats = JVMPoolStats {}
- newtype JVMVersion = JVMVersion {
- unJVMVersion :: Text
- data LoadAvgs = LoadAvgs {}
- newtype MacAddress = MacAddress {
- macAddress :: Text
- newtype NetworkInterfaceName = NetworkInterfaceName {}
- data NodeAttrFilter = NodeAttrFilter {}
- newtype NodeAttrName = NodeAttrName Text
- data NodeBreakerStats = NodeBreakerStats {}
- data NodeBreakersStats = NodeBreakersStats {}
- data NodeDataPathStats = NodeDataPathStats {
- nodeDataPathDiskServiceTime :: Maybe Double
- nodeDataPathDiskQueue :: Maybe Double
- nodeDataPathIOSize :: Maybe Bytes
- nodeDataPathWriteSize :: Maybe Bytes
- nodeDataPathReadSize :: Maybe Bytes
- nodeDataPathIOOps :: Maybe Int
- nodeDataPathWrites :: Maybe Int
- nodeDataPathReads :: Maybe Int
- nodeDataPathAvailable :: Bytes
- nodeDataPathFree :: Bytes
- nodeDataPathTotal :: Bytes
- nodeDataPathType :: Maybe Text
- nodeDataPathDevice :: Maybe Text
- nodeDataPathMount :: Text
- nodeDataPathPath :: Text
- data NodeFSStats = NodeFSStats {}
- data NodeFSTotalStats = NodeFSTotalStats {
- nodeFSTotalDiskServiceTime :: Maybe Double
- nodeFSTotalDiskQueue :: Maybe Double
- nodeFSTotalIOSize :: Maybe Bytes
- nodeFSTotalWriteSize :: Maybe Bytes
- nodeFSTotalReadSize :: Maybe Bytes
- nodeFSTotalIOOps :: Maybe Int
- nodeFSTotalWrites :: Maybe Int
- nodeFSTotalReads :: Maybe Int
- nodeFSTotalAvailable :: Bytes
- nodeFSTotalFree :: Bytes
- nodeFSTotalTotal :: Bytes
- data NodeHTTPInfo = NodeHTTPInfo {}
- data NodeHTTPStats = NodeHTTPStats {}
- data NodeIndicesStats = NodeIndicesStats {
- nodeIndicesStatsRecoveryThrottleTime :: Maybe NominalDiffTime
- nodeIndicesStatsRecoveryCurrentAsTarget :: Maybe Int
- nodeIndicesStatsRecoveryCurrentAsSource :: Maybe Int
- nodeIndicesStatsQueryCacheMisses :: Maybe Int
- nodeIndicesStatsQueryCacheHits :: Maybe Int
- nodeIndicesStatsQueryCacheEvictions :: Maybe Int
- nodeIndicesStatsQueryCacheSize :: Maybe Bytes
- nodeIndicesStatsSuggestCurrent :: Maybe Int
- nodeIndicesStatsSuggestTime :: Maybe NominalDiffTime
- nodeIndicesStatsSuggestTotal :: Maybe Int
- nodeIndicesStatsTranslogSize :: Bytes
- nodeIndicesStatsTranslogOps :: Int
- nodeIndicesStatsSegFixedBitSetMemory :: Maybe Bytes
- nodeIndicesStatsSegVersionMapMemory :: Bytes
- nodeIndicesStatsSegIndexWriterMaxMemory :: Maybe Bytes
- nodeIndicesStatsSegIndexWriterMemory :: Bytes
- nodeIndicesStatsSegMemory :: Bytes
- nodeIndicesStatsSegCount :: Int
- nodeIndicesStatsCompletionSize :: Bytes
- nodeIndicesStatsPercolateQueries :: Maybe Int
- nodeIndicesStatsPercolateMemory :: Maybe Bytes
- nodeIndicesStatsPercolateCurrent :: Maybe Int
- nodeIndicesStatsPercolateTime :: Maybe NominalDiffTime
- nodeIndicesStatsPercolateTotal :: Maybe Int
- nodeIndicesStatsFieldDataEvictions :: Int
- nodeIndicesStatsFieldDataMemory :: Bytes
- nodeIndicesStatsWarmerTotalTime :: NominalDiffTime
- nodeIndicesStatsWarmerTotal :: Int
- nodeIndicesStatsWarmerCurrent :: Int
- nodeIndicesStatsFlushTotalTime :: NominalDiffTime
- nodeIndicesStatsFlushTotal :: Int
- nodeIndicesStatsRefreshTotalTime :: NominalDiffTime
- nodeIndicesStatsRefreshTotal :: Int
- nodeIndicesStatsMergesTotalSize :: Bytes
- nodeIndicesStatsMergesTotalDocs :: Int
- nodeIndicesStatsMergesTotalTime :: NominalDiffTime
- nodeIndicesStatsMergesTotal :: Int
- nodeIndicesStatsMergesCurrentSize :: Bytes
- nodeIndicesStatsMergesCurrentDocs :: Int
- nodeIndicesStatsMergesCurrent :: Int
- nodeIndicesStatsSearchFetchCurrent :: Int
- nodeIndicesStatsSearchFetchTime :: NominalDiffTime
- nodeIndicesStatsSearchFetchTotal :: Int
- nodeIndicesStatsSearchQueryCurrent :: Int
- nodeIndicesStatsSearchQueryTime :: NominalDiffTime
- nodeIndicesStatsSearchQueryTotal :: Int
- nodeIndicesStatsSearchOpenContexts :: Int
- nodeIndicesStatsGetCurrent :: Int
- nodeIndicesStatsGetMissingTime :: NominalDiffTime
- nodeIndicesStatsGetMissingTotal :: Int
- nodeIndicesStatsGetExistsTime :: NominalDiffTime
- nodeIndicesStatsGetExistsTotal :: Int
- nodeIndicesStatsGetTime :: NominalDiffTime
- nodeIndicesStatsGetTotal :: Int
- nodeIndicesStatsIndexingThrottleTime :: Maybe NominalDiffTime
- nodeIndicesStatsIndexingIsThrottled :: Maybe Bool
- nodeIndicesStatsIndexingNoopUpdateTotal :: Maybe Int
- nodeIndicesStatsIndexingDeleteCurrent :: Int
- nodeIndicesStatsIndexingDeleteTime :: NominalDiffTime
- nodeIndicesStatsIndexingDeleteTotal :: Int
- nodeIndicesStatsIndexingIndexCurrent :: Int
- nodeIndicesStatsIndexingIndexTime :: NominalDiffTime
- nodeIndicesStatsIndexingTotal :: Int
- nodeIndicesStatsStoreThrottleTime :: Maybe NominalDiffTime
- nodeIndicesStatsStoreSize :: Bytes
- nodeIndicesStatsDocsDeleted :: Int
- nodeIndicesStatsDocsCount :: Int
- data NodeInfo = NodeInfo {
- nodeInfoHTTPAddress :: Maybe EsAddress
- nodeInfoBuild :: BuildHash
- nodeInfoESVersion :: VersionNumber
- nodeInfoIP :: Server
- nodeInfoHost :: Server
- nodeInfoTransportAddress :: EsAddress
- nodeInfoName :: NodeName
- nodeInfoFullId :: FullNodeId
- nodeInfoPlugins :: [NodePluginInfo]
- nodeInfoHTTP :: NodeHTTPInfo
- nodeInfoTransport :: NodeTransportInfo
- nodeInfoNetwork :: Maybe NodeNetworkInfo
- nodeInfoThreadPool :: Map Text NodeThreadPoolInfo
- nodeInfoJVM :: NodeJVMInfo
- nodeInfoProcess :: NodeProcessInfo
- nodeInfoOS :: NodeOSInfo
- nodeInfoSettings :: Object
- data NodeJVMInfo = NodeJVMInfo {}
- data NodeJVMStats = NodeJVMStats {
- nodeJVMStatsMappedBufferPool :: JVMBufferPoolStats
- nodeJVMStatsDirectBufferPool :: JVMBufferPoolStats
- nodeJVMStatsGCOldCollector :: JVMGCStats
- nodeJVMStatsGCYoungCollector :: JVMGCStats
- nodeJVMStatsPeakThreadsCount :: Int
- nodeJVMStatsThreadsCount :: Int
- nodeJVMStatsOldPool :: JVMPoolStats
- nodeJVMStatsSurvivorPool :: JVMPoolStats
- nodeJVMStatsYoungPool :: JVMPoolStats
- nodeJVMStatsNonHeapCommitted :: Bytes
- nodeJVMStatsNonHeapUsed :: Bytes
- nodeJVMStatsHeapMax :: Bytes
- nodeJVMStatsHeapCommitted :: Bytes
- nodeJVMStatsHeapUsedPercent :: Int
- nodeJVMStatsHeapUsed :: Bytes
- nodeJVMStatsUptime :: NominalDiffTime
- nodeJVMStatsTimestamp :: UTCTime
- data NodeNetworkInfo = NodeNetworkInfo {}
- data NodeNetworkInterface = NodeNetworkInterface {}
- data NodeNetworkStats = NodeNetworkStats {}
- data NodeOSInfo = NodeOSInfo {}
- data NodeOSStats = NodeOSStats {}
- data NodePluginInfo = NodePluginInfo {}
- data NodeProcessInfo = NodeProcessInfo {}
- data NodeProcessStats = NodeProcessStats {}
- data NodeSelection
- data NodeSelector
- data NodeStats = NodeStats {
- nodeStatsName :: NodeName
- nodeStatsFullId :: FullNodeId
- nodeStatsBreakersStats :: Maybe NodeBreakersStats
- nodeStatsHTTP :: NodeHTTPStats
- nodeStatsTransport :: NodeTransportStats
- nodeStatsFS :: NodeFSStats
- nodeStatsNetwork :: Maybe NodeNetworkStats
- nodeStatsThreadPool :: Map Text NodeThreadPoolStats
- nodeStatsJVM :: NodeJVMStats
- nodeStatsProcess :: NodeProcessStats
- nodeStatsOS :: NodeOSStats
- nodeStatsIndices :: NodeIndicesStats
- data NodeThreadPoolInfo = NodeThreadPoolInfo {}
- data NodeThreadPoolStats = NodeThreadPoolStats {}
- data NodeTransportInfo = NodeTransportInfo {}
- data NodeTransportStats = NodeTransportStats {}
- data NodesInfo = NodesInfo {}
- data NodesStats = NodesStats {}
- newtype PID = PID {}
- newtype PluginName = PluginName {
- pluginName :: Text
- data ShardResult = ShardResult {
- shardTotal :: Int
- shardsSuccessful :: Int
- shardsSkipped :: Int
- shardsFailed :: Int
- newtype ShardsResult = ShardsResult {}
- data ThreadPool = ThreadPool {}
- data ThreadPoolSize
- data ThreadPoolType
- newtype VersionNumber = VersionNumber {}
- nodeAttrFilterNameLens :: Lens' NodeAttrFilter NodeAttrName
- nodeAttrFilterValuesLens :: Lens' NodeAttrFilter (NonEmpty Text)
- nodeSelectionNodeListPrism :: Prism' NodeSelection (NonEmpty NodeSelector)
- nodeSelectorNodeByNamePrism :: Prism' NodeSelector NodeName
- nodeSelectorNodeByFullNodeIdPrism :: Prism' NodeSelector FullNodeId
- nodeSelectorNodeByHostPrism :: Prism' NodeSelector Server
- nodeSelectorNodeByAttributePrism :: Prism' NodeSelector (NodeAttrName, Text)
- nodesInfoListLens :: Lens' NodesInfo [NodeInfo]
- nodesClusterNameLens :: Lens' NodesInfo ClusterName
- nodesStatsListLens :: Lens' NodesStats [NodeStats]
- nodesStatsClusterNameLens :: Lens' NodesStats ClusterName
- nodeStatsNameLens :: Lens' NodeStats NodeName
- nodeStatsFullIdLens :: Lens' NodeStats FullNodeId
- nodeStatsBreakersStatsLens :: Lens' NodeStats (Maybe NodeBreakersStats)
- nodeStatsHTTPLens :: Lens' NodeStats NodeHTTPStats
- nodeStatsTransportLens :: Lens' NodeStats NodeTransportStats
- nodeStatsFSLens :: Lens' NodeStats NodeFSStats
- nodeStatsNetworkLens :: Lens' NodeStats (Maybe NodeNetworkStats)
- nodeStatsThreadPoolLens :: Lens' NodeStats (Map Text NodeThreadPoolStats)
- nodeStatsJVMLens :: Lens' NodeStats NodeJVMStats
- nodeStatsProcessLens :: Lens' NodeStats NodeProcessStats
- nodeStatsOSLens :: Lens' NodeStats NodeOSStats
- nodeStatsIndicesLens :: Lens' NodeStats NodeIndicesStats
- nodeStatsParentBreakerLens :: Lens' NodeBreakersStats NodeBreakerStats
- nodeStatsRequestBreakerLens :: Lens' NodeBreakersStats NodeBreakerStats
- nodeStatsFieldDataBreakerLens :: Lens' NodeBreakersStats NodeBreakerStats
- nodeBreakersStatsTrippedLens :: Lens' NodeBreakerStats Int
- nodeBreakersStatsOverheadLens :: Lens' NodeBreakerStats Double
- nodeBreakersStatsEstSizeLens :: Lens' NodeBreakerStats Bytes
- nodeBreakersStatsLimitSizeLens :: Lens' NodeBreakerStats Bytes
- nodeHTTPTotalStatsOpenedLens :: Lens' NodeHTTPStats Int
- nodeHTTPStatsCurrentOpenLens :: Lens' NodeHTTPStats Int
- nodeTransportStatsTXSizeLens :: Lens' NodeTransportStats Bytes
- nodeTransportStatsCountLens :: Lens' NodeTransportStats Int
- nodeTransportStatsRXSizeLens :: Lens' NodeTransportStats Bytes
- nodeTransportStatsRXCountLens :: Lens' NodeTransportStats Int
- nodeTransportStatsServerOpenLens :: Lens' NodeTransportStats Int
- nodeFSStatsDataPathsLens :: Lens' NodeFSStats [NodeDataPathStats]
- nodeFSStatsTotalLens :: Lens' NodeFSStats NodeFSTotalStats
- nodeFSStatsTimestampLens :: Lens' NodeFSStats UTCTime
- nodeDataPathStatsDiskServiceTimeLens :: Lens' NodeDataPathStats (Maybe Double)
- nodeDataPathStatsDiskQueueLens :: Lens' NodeDataPathStats (Maybe Double)
- nodeDataPathStatsIOSizeLens :: Lens' NodeDataPathStats (Maybe Bytes)
- nodeDataPathStatsWriteSizeLens :: Lens' NodeDataPathStats (Maybe Bytes)
- nodeDataPathStatsReadSizeLens :: Lens' NodeDataPathStats (Maybe Bytes)
- nodeDataPathStatsIOOpsLens :: Lens' NodeDataPathStats (Maybe Int)
- nodeDataPathStatsWritesLens :: Lens' NodeDataPathStats (Maybe Int)
- nodeDataPathStatsReadsLens :: Lens' NodeDataPathStats (Maybe Int)
- nodeDataPathStatsAvailableLens :: Lens' NodeDataPathStats Bytes
- nodeDataPathStatsFreeLens :: Lens' NodeDataPathStats Bytes
- nodeDataPathStatsTotalLens :: Lens' NodeDataPathStats Bytes
- nodeDataPathStatsTypeLens :: Lens' NodeDataPathStats (Maybe Text)
- nodeDataPathStatsDeviceLens :: Lens' NodeDataPathStats (Maybe Text)
- nodeDataPathStatsMountLens :: Lens' NodeDataPathStats Text
- nodeDataPathStatsPathLens :: Lens' NodeDataPathStats Text
- nodeFSTotalStatsDiskServiceTimeLens :: Lens' NodeFSTotalStats (Maybe Double)
- nodeFSTotalStatsDiskQueueLens :: Lens' NodeFSTotalStats (Maybe Double)
- nodeFSTotalStatsIOSizeLens :: Lens' NodeFSTotalStats (Maybe Bytes)
- nodeFSTotalStatsWriteSizeLens :: Lens' NodeFSTotalStats (Maybe Bytes)
- nodeFSTotalStatsReadSizeLens :: Lens' NodeFSTotalStats (Maybe Bytes)
- nodeFSTotalStatsIOOpsLens :: Lens' NodeFSTotalStats (Maybe Int)
- nodeFSTotalStatsWritesLens :: Lens' NodeFSTotalStats (Maybe Int)
- nodeFSTotalStatsReadsLens :: Lens' NodeFSTotalStats (Maybe Int)
- nodeFSTotalStatsAvailableLens :: Lens' NodeFSTotalStats Bytes
- nodeFSTotalStatsFreeLens :: Lens' NodeFSTotalStats Bytes
- nodeFSTotalStatsTotalLens :: Lens' NodeFSTotalStats Bytes
- nodeNetworkStatsTCPOutRSTsLens :: Lens' NodeNetworkStats Int
- nodeNetworkStatsTCPInErrsLens :: Lens' NodeNetworkStats Int
- nodeNetworkStatsTCPAttemptFailsLens :: Lens' NodeNetworkStats Int
- nodeNetworkStatsTCPEstabResetsLens :: Lens' NodeNetworkStats Int
- nodeNetworkStatsTCPRetransSegsLens :: Lens' NodeNetworkStats Int
- nodeNetworkStatsTCPOutSegsLens :: Lens' NodeNetworkStats Int
- nodeNetworkStatsTCPInSegsLens :: Lens' NodeNetworkStats Int
- nodeNetworkStatsTCPCurrEstabLens :: Lens' NodeNetworkStats Int
- nodeNetworkStatsTCPPassiveOpensLens :: Lens' NodeNetworkStats Int
- nodeNetworkStatsTCPActiveOpensLens :: Lens' NodeNetworkStats Int
- nodeThreadPoolStatsCompletedLens :: Lens' NodeThreadPoolStats Int
- nodeThreadPoolStatsLargestLens :: Lens' NodeThreadPoolStats Int
- nodeThreadPoolStatsRejectedLens :: Lens' NodeThreadPoolStats Int
- nodeThreadPoolStatsActiveLens :: Lens' NodeThreadPoolStats Int
- nodeThreadPoolStatsQueueLens :: Lens' NodeThreadPoolStats Int
- nodeThreadPoolStatsThreadsLens :: Lens' NodeThreadPoolStats Int
- nodeJVMStatsMappedBufferPoolLens :: Lens' NodeJVMStats JVMBufferPoolStats
- nodeJVMStatsDirectBufferPoolLens :: Lens' NodeJVMStats JVMBufferPoolStats
- nodeJVMStatsGCOldCollectorLens :: Lens' NodeJVMStats JVMGCStats
- nodeJVMStatsGCYoungCollectorLens :: Lens' NodeJVMStats JVMGCStats
- nodeJVMStatsPeakThreadsCountLens :: Lens' NodeJVMStats Int
- nodeJVMStatsThreadsCountLens :: Lens' NodeJVMStats Int
- nodeJVMStatsOldPoolLens :: Lens' NodeJVMStats JVMPoolStats
- nodeJVMStatsSurvivorPoolLens :: Lens' NodeJVMStats JVMPoolStats
- nodeJVMStatsYoungPoolLens :: Lens' NodeJVMStats JVMPoolStats
- nodeJVMStatsNonHeapCommittedLens :: Lens' NodeJVMStats Bytes
- nodeJVMStatsNonHeapUsedLens :: Lens' NodeJVMStats Bytes
- nodeJVMStatsHeapMaxLens :: Lens' NodeJVMStats Bytes
- nodeJVMStatsHeapCommittedLens :: Lens' NodeJVMStats Bytes
- nodeJVMStatsHeapUsedPercentLens :: Lens' NodeJVMStats Int
- nodeJVMStatsHeapUsedLens :: Lens' NodeJVMStats Bytes
- nodeJVMStatsUptimeLens :: Lens' NodeJVMStats NominalDiffTime
- nodeJVMStatsTimestampLens :: Lens' NodeJVMStats UTCTime
- jvmBufferPoolStatsTotalCapacityLens :: Lens' JVMBufferPoolStats Bytes
- jvmBufferPoolStatsUsedLens :: Lens' JVMBufferPoolStats Bytes
- jvmBufferPoolStatsCountLens :: Lens' JVMBufferPoolStats Int
- jvmGCStatsCollectionTimeLens :: Lens' JVMGCStats NominalDiffTime
- jvmGCStatsCollectionCountLens :: Lens' JVMGCStats Int
- jvmPoolStatsPeakMaxLens :: Lens' JVMPoolStats Bytes
- jvmPoolStatsPeakUsedLens :: Lens' JVMPoolStats Bytes
- jvmPoolStatsMaxLens :: Lens' JVMPoolStats Bytes
- jvmPoolStatsUsedLens :: Lens' JVMPoolStats Bytes
- nodeProcessStatsTimestampLens :: Lens' NodeProcessStats UTCTime
- nodeProcessStatsOpenFDsLens :: Lens' NodeProcessStats Int
- nodeProcessStatsMaxFDsLens :: Lens' NodeProcessStats Int
- nodeProcessStatsCPUPercentLens :: Lens' NodeProcessStats Int
- nodeProcessStatsCPUTotalLens :: Lens' NodeProcessStats NominalDiffTime
- nodeProcessStatsMemTotalVirtualLens :: Lens' NodeProcessStats Bytes
- nodeOSStatsTimestampLens :: Lens' NodeOSStats UTCTime
- nodeOSStatsCPUPercentLens :: Lens' NodeOSStats Int
- nodeOSStatsLoadLens :: Lens' NodeOSStats (Maybe LoadAvgs)
- nodeOSStatsMemTotalLens :: Lens' NodeOSStats Bytes
- nodeOSStatsMemFreeLens :: Lens' NodeOSStats Bytes
- nodeOSStatsMemFreePercentLens :: Lens' NodeOSStats Int
- nodeOSStatsMemUsedLens :: Lens' NodeOSStats Bytes
- nodeOSStatsMemUsedPercentLens :: Lens' NodeOSStats Int
- nodeOSStatsSwapTotalLens :: Lens' NodeOSStats Bytes
- nodeOSStatsSwapFreeLens :: Lens' NodeOSStats Bytes
- nodeOSStatsSwapUsedLens :: Lens' NodeOSStats Bytes
- loadAvgs1MinLens :: Lens' LoadAvgs Double
- loadAvgs5MinLens :: Lens' LoadAvgs Double
- loadAvgs15MinLens :: Lens' LoadAvgs Double
- nodeIndicesStatsRecoveryThrottleTimeLens :: Lens' NodeIndicesStats (Maybe NominalDiffTime)
- nodeIndicesStatsRecoveryCurrentAsTargetLens :: Lens' NodeIndicesStats (Maybe Int)
- nodeIndicesStatsRecoveryCurrentAsSourceLens :: Lens' NodeIndicesStats (Maybe Int)
- nodeIndicesStatsQueryCacheMissesLens :: Lens' NodeIndicesStats (Maybe Int)
- nodeIndicesStatsQueryCacheHitsLens :: Lens' NodeIndicesStats (Maybe Int)
- nodeIndicesStatsQueryCacheEvictionsLens :: Lens' NodeIndicesStats (Maybe Int)
- nodeIndicesStatsQueryCacheSizeLens :: Lens' NodeIndicesStats (Maybe Bytes)
- nodeIndicesStatsSuggestCurrentLens :: Lens' NodeIndicesStats (Maybe Int)
- nodeIndicesStatsSuggestTimeLens :: Lens' NodeIndicesStats (Maybe NominalDiffTime)
- nodeIndicesStatsSuggestTotalLens :: Lens' NodeIndicesStats (Maybe Int)
- nodeIndicesStatsTranslogSizeLens :: Lens' NodeIndicesStats Bytes
- nodeIndicesStatsTranslogOpsLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsSegFixedBitSetMemoryLens :: Lens' NodeIndicesStats (Maybe Bytes)
- nodeIndicesStatsSegVersionMapMemoryLens :: Lens' NodeIndicesStats Bytes
- nodeIndicesStatsSegIndexWriterMaxMemoryLens :: Lens' NodeIndicesStats (Maybe Bytes)
- nodeIndicesStatsSegIndexWriterMemoryLens :: Lens' NodeIndicesStats Bytes
- nodeIndicesStatsSegMemoryLens :: Lens' NodeIndicesStats Bytes
- nodeIndicesStatsSegCountLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsCompletionSizeLens :: Lens' NodeIndicesStats Bytes
- nodeIndicesStatsPercolateQueriesLens :: Lens' NodeIndicesStats (Maybe Int)
- nodeIndicesStatsPercolateMemoryLens :: Lens' NodeIndicesStats (Maybe Bytes)
- nodeIndicesStatsPercolateCurrentLens :: Lens' NodeIndicesStats (Maybe Int)
- nodeIndicesStatsPercolateTimeLens :: Lens' NodeIndicesStats (Maybe NominalDiffTime)
- nodeIndicesStatsPercolateTotalLens :: Lens' NodeIndicesStats (Maybe Int)
- nodeIndicesStatsFieldDataEvictionsLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsFieldDataMemoryLens :: Lens' NodeIndicesStats Bytes
- nodeIndicesStatsWarmerTotalTimeLens :: Lens' NodeIndicesStats NominalDiffTime
- nodeIndicesStatsWarmerTotalLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsWarmerCurrentLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsFlushTotalTimeLens :: Lens' NodeIndicesStats NominalDiffTime
- nodeIndicesStatsFlushTotalLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsRefreshTotalTimeLens :: Lens' NodeIndicesStats NominalDiffTime
- nodeIndicesStatsRefreshTotalLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsMergesTotalSizeLens :: Lens' NodeIndicesStats Bytes
- nodeIndicesStatsMergesTotalDocsLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsMergesTotalTimeLens :: Lens' NodeIndicesStats NominalDiffTime
- nodeIndicesStatsMergesTotalLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsMergesCurrentSizeLens :: Lens' NodeIndicesStats Bytes
- nodeIndicesStatsMergesCurrentDocsLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsMergesCurrentLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsSearchFetchCurrentLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsSearchFetchTimeLens :: Lens' NodeIndicesStats NominalDiffTime
- nodeIndicesStatsSearchFetchTotalLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsSearchQueryCurrentLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsSearchQueryTimeLens :: Lens' NodeIndicesStats NominalDiffTime
- nodeIndicesStatsSearchQueryTotalLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsSearchOpenContextsLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsGetCurrentLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsGetMissingTimeLens :: Lens' NodeIndicesStats NominalDiffTime
- nodeIndicesStatsGetMissingTotalLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsGetExistsTimeLens :: Lens' NodeIndicesStats NominalDiffTime
- nodeIndicesStatsGetExistsTotalLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsGetTimeLens :: Lens' NodeIndicesStats NominalDiffTime
- nodeIndicesStatsGetTotalLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsIndexingThrottleTimeLens :: Lens' NodeIndicesStats (Maybe NominalDiffTime)
- nodeIndicesStatsIndexingIsThrottledLens :: Lens' NodeIndicesStats (Maybe Bool)
- nodeIndicesStatsIndexingNoopUpdateTotalLens :: Lens' NodeIndicesStats (Maybe Int)
- nodeIndicesStatsIndexingDeleteCurrentLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsIndexingDeleteTimeLens :: Lens' NodeIndicesStats NominalDiffTime
- nodeIndicesStatsIndexingDeleteTotalLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsIndexingIndexCurrentLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsIndexingIndexTimeLens :: Lens' NodeIndicesStats NominalDiffTime
- nodeIndicesStatsIndexingTotalLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsStoreThrottleTimeLens :: Lens' NodeIndicesStats (Maybe NominalDiffTime)
- nodeIndicesStatsStoreSizeLens :: Lens' NodeIndicesStats Bytes
- nodeIndicesStatsDocsDeletedLens :: Lens' NodeIndicesStats Int
- nodeIndicesStatsDocsCountLens :: Lens' NodeIndicesStats Int
- nodeInfoHTTPAddressLens :: Lens' NodeInfo (Maybe EsAddress)
- nodeInfoBuildLens :: Lens' NodeInfo BuildHash
- nodeInfoESVersionLens :: Lens' NodeInfo VersionNumber
- nodeInfoIPLens :: Lens' NodeInfo Server
- nodeInfoHostLens :: Lens' NodeInfo Server
- nodeInfoTransportAddressLens :: Lens' NodeInfo EsAddress
- nodeInfoNameLens :: Lens' NodeInfo NodeName
- nodeInfoFullIdLens :: Lens' NodeInfo FullNodeId
- nodeInfoPluginsLens :: Lens' NodeInfo [NodePluginInfo]
- nodeInfoHTTPLens :: Lens' NodeInfo NodeHTTPInfo
- nodeInfoTransportLens :: Lens' NodeInfo NodeTransportInfo
- nodeInfoNetworkLens :: Lens' NodeInfo (Maybe NodeNetworkInfo)
- nodeInfoThreadPoolLens :: Lens' NodeInfo (Map Text NodeThreadPoolInfo)
- nodeInfoJVMLens :: Lens' NodeInfo NodeJVMInfo
- nodeInfoProcessLens :: Lens' NodeInfo NodeProcessInfo
- nodeInfoOSLens :: Lens' NodeInfo NodeOSInfo
- nodeInfoSettingsLens :: Lens' NodeInfo Object
- nodePluginSiteLens :: Lens' NodePluginInfo (Maybe Bool)
- nodePluginInfoJVMLens :: Lens' NodePluginInfo (Maybe Bool)
- nodePluginInfoDescriptionLens :: Lens' NodePluginInfo Text
- nodePluginInfoVersionLens :: Lens' NodePluginInfo (MaybeNA VersionNumber)
- nodePluginInfoNameLens :: Lens' NodePluginInfo PluginName
- nodeHTTPInfoMaxContentLengthLens :: Lens' NodeHTTPInfo Bytes
- nodeHTTPInfopublishAddressLens :: Lens' NodeHTTPInfo EsAddress
- nodeHTTPInfoBoundAddressesLens :: Lens' NodeHTTPInfo [EsAddress]
- nodeTransportInfoProfilesLens :: Lens' NodeTransportInfo [BoundTransportAddress]
- nodeTransportInfoPublishAddressLens :: Lens' NodeTransportInfo EsAddress
- nodeTransportInfoBoundAddressLens :: Lens' NodeTransportInfo [EsAddress]
- boundTransportAddressPublishAddressLens :: Lens' BoundTransportAddress EsAddress
- boundTransportAddressBoundAddressesLens :: Lens' BoundTransportAddress [EsAddress]
- nodeNetworkInfoPrimaryInterfaceLens :: Lens' NodeNetworkInfo NodeNetworkInterface
- nodeNetworkInfoRefreshIntervalLens :: Lens' NodeNetworkInfo NominalDiffTime
- nodeNetworkInterfaceMacAddressLens :: Lens' NodeNetworkInterface MacAddress
- nodeNetworkInterfaceNameLens :: Lens' NodeNetworkInterface NetworkInterfaceName
- nodeNetworkInterfaceAddressLens :: Lens' NodeNetworkInterface Server
- threadPoolNodeThreadPoolNameLens :: Lens' ThreadPool Text
- threadPoolNodeThreadPoolInfoLens :: Lens' ThreadPool NodeThreadPoolInfo
- nodeThreadPoolInfoQueueSizeLens :: Lens' NodeThreadPoolInfo ThreadPoolSize
- nodeThreadPoolInfoKeepaliveLens :: Lens' NodeThreadPoolInfo (Maybe NominalDiffTime)
- nodeThreadPoolInfoMinLens :: Lens' NodeThreadPoolInfo (Maybe Int)
- nodeThreadPoolInfoMaxLens :: Lens' NodeThreadPoolInfo (Maybe Int)
- nodeThreadPoolInfoTypeLens :: Lens' NodeThreadPoolInfo ThreadPoolType
- threadPoolSizeBoundedPrism :: Prism' ThreadPoolSize Int
- nodeJVMInfoMemoryPoolsLens :: Lens' NodeJVMInfo [JVMMemoryPool]
- nodeJVMInfoMemoryPoolsGCCollectorsLens :: Lens' NodeJVMInfo [JVMGCCollector]
- nodeJVMInfoMemoryInfoLens :: Lens' NodeJVMInfo JVMMemoryInfo
- nodeJVMInfoStartTimeLens :: Lens' NodeJVMInfo UTCTime
- nodeJVMInfoVMVendorLens :: Lens' NodeJVMInfo Text
- nodeJVMInfoVMVersionLens :: Lens' NodeJVMInfo VersionNumber
- nodeJVMInfoVMNameLens :: Lens' NodeJVMInfo Text
- nodeJVMInfoVersionLens :: Lens' NodeJVMInfo JVMVersion
- nodeJVMInfoPIDLens :: Lens' NodeJVMInfo PID
- jvmMemoryInfoDirectMaxLens :: Lens' JVMMemoryInfo Bytes
- jvmMemoryInfoNonHeapMaxLens :: Lens' JVMMemoryInfo Bytes
- jvmMemoryInfoNonHeapInitLens :: Lens' JVMMemoryInfo Bytes
- jvmMemoryInfoHeapMaxLens :: Lens' JVMMemoryInfo Bytes
- jvmMemoryInfoHeapInitLens :: Lens' JVMMemoryInfo Bytes
- nodeOSInfoRefreshIntervalLens :: Lens' NodeOSInfo NominalDiffTime
- nodeOSInfoNameLens :: Lens' NodeOSInfo Text
- nodeOSInfoArchLens :: Lens' NodeOSInfo Text
- nodeOSInfoVersionLens :: Lens' NodeOSInfo Text
- nodeOSInfoAvailableProcessorsLens :: Lens' NodeOSInfo Int
- nodeOSInfoAllocatedProcessorsLens :: Lens' NodeOSInfo Int
- cpuInfoCacheSizeLens :: Lens' CPUInfo Bytes
- cpuInfoCoresPerSocketLens :: Lens' CPUInfo Int
- cpuInfoTotalSocketsLens :: Lens' CPUInfo Int
- cpuInfoTotalCoresLens :: Lens' CPUInfo Int
- cpuInfoMHZLens :: Lens' CPUInfo Int
- cpuInfoModelLens :: Lens' CPUInfo Text
- cpuInfoVendorLens :: Lens' CPUInfo Text
- nodeProcessInfoMLockAllLens :: Lens' NodeProcessInfo Bool
- nodeProcessInfoMaxFileDescriptorsLens :: Lens' NodeProcessInfo (Maybe Int)
- nodeProcessInfoIdLens :: Lens' NodeProcessInfo PID
- nodeProcessInfoRefreshIntervalLens :: Lens' NodeProcessInfo NominalDiffTime
- initialShardCountExplicitShardsPrism :: Prism' InitialShardCount Int
- shardsResultShardsLens :: Lens' ShardsResult ShardResult
- shardResultTotalLens :: Lens' ShardResult Int
- shardsResultSuccessfulLens :: Lens' ShardResult Int
- shardsResultResultSkippedLens :: Lens' ShardResult Int
- shardsResultFailedLens :: Lens' ShardResult Int
- versionNumberLens :: Lens' Version VersionNumber
- versionBuildHashLens :: Lens' Version BuildHash
- versionBuildDateLens :: Lens' Version UTCTime
- versionBuildSnapshotLens :: Lens' Version Bool
- versionLuceneVersionLens :: Lens' Version VersionNumber
- healthStatusClusterNameLens :: Lens' HealthStatus Text
- healthStatusStatusLens :: Lens' HealthStatus Text
- healthStatusTimedOutLens :: Lens' HealthStatus Bool
- healthStatusNumberOfNodesLens :: Lens' HealthStatus Int
- healthStatusNumberOfDataNodesLens :: Lens' HealthStatus Int
- healthStatusActivePrimaryShardsLens :: Lens' HealthStatus Int
- healthStatusActiveShardsLens :: Lens' HealthStatus Int
- healthStatusRelocatingShardsLens :: Lens' HealthStatus Int
- healthStatusInitializingShardsLens :: Lens' HealthStatus Int
- healthStatusUnassignedShardsLens :: Lens' HealthStatus Int
- healthStatusDelayedUnassignedShardsLens :: Lens' HealthStatus Int
- healthStatusNumberOfPendingTasksLens :: Lens' HealthStatus Int
- healthStatusNumberOfInFlightFetchLens :: Lens' HealthStatus Int
- healthStatusTaskMaxWaitingInQueueMillisLens :: Lens' HealthStatus Int
- healthStatusActiveShardsPercentAsNumberLens :: Lens' HealthStatus Float
- indexedDocumentIndexLens :: Lens' IndexedDocument Text
- indexedDocumentTypeLens :: Lens' IndexedDocument (Maybe Text)
- indexedDocumentIdLens :: Lens' IndexedDocument Text
- indexedDocumentVersionLens :: Lens' IndexedDocument Int
- indexedDocumentResultLens :: Lens' IndexedDocument Text
- indexedDocumentShardsLens :: Lens' IndexedDocument ShardResult
- indexedDocumentSeqNoLens :: Lens' IndexedDocument Int
- indexedDocumentPrimaryTermLens :: Lens' IndexedDocument Int
- deletedDocumentsTookLens :: Lens' DeletedDocuments Int
- deletedDocumentsTimedOutLens :: Lens' DeletedDocuments Bool
- deletedDocumentsTotalLens :: Lens' DeletedDocuments Int
- deletedDocumentsDeletedLens :: Lens' DeletedDocuments Int
- deletedDocumentsBatchesLens :: Lens' DeletedDocuments Int
- deletedDocumentsVersionConflictsLens :: Lens' DeletedDocuments Int
- deletedDocumentsNoopsLens :: Lens' DeletedDocuments Int
- deletedDocumentsRetriesLens :: Lens' DeletedDocuments DeletedDocumentsRetries
- deletedDocumentsThrottledMillisLens :: Lens' DeletedDocuments Int
- deletedDocumentsRequestsPerSecondLens :: Lens' DeletedDocuments Float
- deletedDocumentsThrottledUntilMillisLens :: Lens' DeletedDocuments Int
- deletedDocumentsFailuresLens :: Lens' DeletedDocuments [Value]
- deletedDocumentsRetriesBulkLens :: Lens' DeletedDocumentsRetries Int
- deletedDocumentsRetriesSearchLens :: Lens' DeletedDocumentsRetries Int
- data FsSnapshotRepo = FsSnapshotRepo {}
- data GenericSnapshotRepo = GenericSnapshotRepo {}
- newtype GenericSnapshotRepoSettings = GenericSnapshotRepoSettings {}
- newtype RRGroupRefNum = RRGroupRefNum {
- rrGroupRefNum :: Int
- newtype RestoreIndexSettings = RestoreIndexSettings {}
- newtype RestoreRenamePattern = RestoreRenamePattern {}
- data RestoreRenameToken
- data SnapshotCreateSettings = SnapshotCreateSettings {}
- data SnapshotInfo = SnapshotInfo {}
- data SnapshotNodeVerification = SnapshotNodeVerification {}
- data SnapshotPattern
- class SnapshotRepo r where
- data SnapshotRepoConversionError
- newtype SnapshotRepoName = SnapshotRepoName {}
- data SnapshotRepoPattern
- data SnapshotRepoSelection
- newtype SnapshotRepoType = SnapshotRepoType {}
- newtype SnapshotRepoUpdateSettings = SnapshotRepoUpdateSettings {}
- data SnapshotRestoreSettings = SnapshotRestoreSettings {
- snapRestoreWaitForCompletion :: Bool
- snapRestoreIndices :: Maybe IndexSelection
- snapRestoreIgnoreUnavailable :: Bool
- snapRestoreIncludeGlobalState :: Bool
- snapRestoreRenamePattern :: Maybe RestoreRenamePattern
- snapRestoreRenameReplacement :: Maybe (NonEmpty RestoreRenameToken)
- snapRestorePartial :: Bool
- snapRestoreIncludeAliases :: Bool
- snapRestoreIndexSettingsOverrides :: Maybe RestoreIndexSettings
- snapRestoreIgnoreIndexSettings :: Maybe (NonEmpty Text)
- data SnapshotSelection
- data SnapshotShardFailure = SnapshotShardFailure {}
- data SnapshotState
- newtype SnapshotVerification = SnapshotVerification {}
- defaultSnapshotCreateSettings :: SnapshotCreateSettings
- defaultSnapshotRepoUpdateSettings :: SnapshotRepoUpdateSettings
- defaultSnapshotRestoreSettings :: SnapshotRestoreSettings
- mkRRGroupRefNum :: Int -> Maybe RRGroupRefNum
- snapshotRepoNameLens :: Lens' SnapshotRepoName Text
- genericSnapshotRepoNameLens :: Lens' GenericSnapshotRepo SnapshotRepoName
- genericSnapshotRepoTypeLens :: Lens' GenericSnapshotRepo SnapshotRepoType
- genericSnapshotRepoSettingsLens :: Lens' GenericSnapshotRepo GenericSnapshotRepoSettings
- snapshotRepoTypeLens :: Lens' SnapshotRepoType Text
- genericSnapshotRepoSettingsObjectLens :: Lens' GenericSnapshotRepoSettings Object
- snapshotNodeVerificationsLens :: Lens' SnapshotVerification [SnapshotNodeVerification]
- snapshotNodeVerificationFullIdLens :: Lens' SnapshotNodeVerification FullNodeId
- snapshotNodeVerificationNodeNameLens :: Lens' SnapshotNodeVerification NodeName
- snapshotRestoreSettingsWaitForCompletionLens :: Lens' SnapshotRestoreSettings Bool
- snapshotRestoreSettingsIndicesLens :: Lens' SnapshotRestoreSettings (Maybe IndexSelection)
- snapshotRestoreSettingsIgnoreUnavailableLens :: Lens' SnapshotRestoreSettings Bool
- snapshotRestoreSettingsIncludeGlobalStateLens :: Lens' SnapshotRestoreSettings Bool
- snapshotRestoreSettingsRenamePatternLens :: Lens' SnapshotRestoreSettings (Maybe RestoreRenamePattern)
- snapshotRestoreSettingsRenameReplacementLens :: Lens' SnapshotRestoreSettings (Maybe (NonEmpty RestoreRenameToken))
- snapshotRestoreSettingsPartialLens :: Lens' SnapshotRestoreSettings Bool
- snapshotRestoreSettingsIncludeAliasesLens :: Lens' SnapshotRestoreSettings Bool
- snapshotRestoreSettingsIndexSettingsOverridesLens :: Lens' SnapshotRestoreSettings (Maybe RestoreIndexSettings)
- snapshotRestoreSettingsIgnoreIndexSettingsLens :: Lens' SnapshotRestoreSettings (Maybe (NonEmpty Text))
- snapshotRepoUpdateSettingsUpdateVerifyLens :: Lens' SnapshotRepoUpdateSettings Bool
- fsSnapshotRepoNameLens :: Lens' FsSnapshotRepo SnapshotRepoName
- fsSnapshotRepoLocationLens :: Lens' FsSnapshotRepo FilePath
- fsSnapshotRepoCompressMetadataLens :: Lens' FsSnapshotRepo Bool
- fsSnapshotRepoChunkSizeLens :: Lens' FsSnapshotRepo (Maybe Bytes)
- fsSnapshotRepoMaxRestoreBytesPerSecLens :: Lens' FsSnapshotRepo (Maybe Bytes)
- fsSnapshotRepoMaxSnapshotBytesPerSecLens :: Lens' FsSnapshotRepo (Maybe Bytes)
- snapshotCreateSettingsWaitForCompletionLens :: Lens' SnapshotCreateSettings Bool
- snapshotCreateSettingsIndicesLens :: Lens' SnapshotCreateSettings (Maybe IndexSelection)
- snapshotCreateSettingsIgnoreUnavailableLens :: Lens' SnapshotCreateSettings Bool
- snapshotCreateSettingsIncludeGlobalStateLens :: Lens' SnapshotCreateSettings Bool
- snapshotCreateSettingsPartialLens :: Lens' SnapshotCreateSettings Bool
- snapshotInfoShardsLens :: Lens' SnapshotInfo ShardResult
- snapshotInfoFailuresLens :: Lens' SnapshotInfo [SnapshotShardFailure]
- snapshotInfoDurationLens :: Lens' SnapshotInfo NominalDiffTime
- snapshotInfoEndTimeLens :: Lens' SnapshotInfo UTCTime
- snapshotInfoStartTimeLens :: Lens' SnapshotInfo UTCTime
- snapshotInfoStateLens :: Lens' SnapshotInfo SnapshotState
- snapshotInfoIndicesLens :: Lens' SnapshotInfo [IndexName]
- snapshotInfoNameLens :: Lens' SnapshotInfo SnapshotName
- snapshotShardFailureIndexLens :: Lens' SnapshotShardFailure IndexName
- snapshotShardFailureNodeIdLens :: Lens' SnapshotShardFailure (Maybe NodeName)
- snapshotShardFailureReasonLens :: Lens' SnapshotShardFailure Text
- snapshotShardFailureShardIdLens :: Lens' SnapshotShardFailure ShardId
- restoreRenamePatternLens :: Lens' RestoreRenamePattern Text
- restoreIndexSettingsOverrideReplicasLens :: Lens' RestoreIndexSettings (Maybe ReplicaCount)
- data TimeInterval
- gigabytes :: Int -> Bytes
- kilobytes :: Int -> Bytes
- megabytes :: Int -> Bytes
- parseStringInterval :: (Monad m, MonadFail m) => String -> m NominalDiffTime
- newtype BH (m :: Type -> Type) a = BH {}
- data BHEnv = BHEnv {}
- class (Functor m, Applicative m, MonadIO m, MonadCatch m) => MonadBH (m :: Type -> Type) where
- type Backend (m :: Type -> Type) :: BackendType
- dispatch :: BHRequest contextualized body -> m (BHResponse contextualized body)
- tryEsError :: m a -> m (Either EsError a)
- throwEsError :: EsError -> m a
- data BackendType
- type WithBackend (backend :: BackendType) (m :: Type -> Type) = WithBackendType backend (Backend m)
- type family WithBackendType (expected :: BackendType) (actual :: BackendType) where ...
- newtype StaticBH (backend :: BackendType) (m :: Type -> Type) a = StaticBH {
- runStaticBH :: m a
- data SBackendType (a :: BackendType) where
- emptyBody :: ByteString
- mkBHEnv :: Server -> Manager -> BHEnv
- performBHRequest :: (MonadBH m, MonadThrow m, ParseBHResponse contextualized) => BHRequest contextualized a -> m a
- runBH :: BHEnv -> BH m a -> m (Either EsError a)
- tryPerformBHRequest :: (MonadBH m, MonadThrow m, ParseBHResponse contextualized) => BHRequest contextualized a -> m (ParsedEsResponse a)
- unsafePerformBH :: forall (backend :: BackendType) m a. StaticBH backend m a -> m a
- withDynamicBH :: MonadBH m => BackendType -> (forall (backend :: BackendType). SBackendType backend -> StaticBH backend m a) -> m a
Documentation
Version
is embedded in Status
Constructors
Version | |
Fields |
Instances
data BulkAction Source #
Instances
Show BulkAction Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Bulk Methods showsPrec :: Int -> BulkAction -> ShowS # show :: BulkAction -> String # showList :: [BulkAction] -> ShowS # | |
Eq BulkAction Source # | |
Status
is a data type for describing the JSON body returned by
Elasticsearch when you query its status. This was deprecated in 1.2.0.
http://www.elastic.co/guide/en/elasticsearch/reference/current/indices-status.html#indices-status
Constructors
Status | |
Fields
|
Support for type reification of Mapping
s is currently incomplete, for
now the mapping API verbiage expects a ToJSON
able blob.
Indexes have mappings, mappings are schemas for the documents contained in the index. I'd recommend having only one mapping per index, always having a mapping, and keeping different kinds of documents separated if possible.
Constructors
Mapping | |
Fields |
A measure of bytes used for various configurations. You may want
to use smart constructors like gigabytes
for larger values.
>>>
gigabytes 9
Bytes 9000000000
>>>
megabytes 9
Bytes 9000000
>>>
kilobytes 9
Bytes 9000
A human-readable node name that is supplied by the user in the node config or automatically generated by Elasticsearch.
data HealthStatus Source #
Constructors
HealthStatus | |
Fields
|
Instances
FromJSON HealthStatus Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show HealthStatus Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> HealthStatus -> ShowS # show :: HealthStatus -> String # showList :: [HealthStatus] -> ShowS # | |
Eq HealthStatus Source # | |
data IndexedDocument Source #
Constructors
IndexedDocument | |
Fields
|
Instances
FromJSON IndexedDocument Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser IndexedDocument # parseJSONList :: Value -> Parser [IndexedDocument] # | |
Show IndexedDocument Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> IndexedDocument -> ShowS # show :: IndexedDocument -> String # showList :: [IndexedDocument] -> ShowS # | |
Eq IndexedDocument Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: IndexedDocument -> IndexedDocument -> Bool # (/=) :: IndexedDocument -> IndexedDocument -> Bool # |
data DeletedDocuments Source #
Constructors
DeletedDocuments | |
Fields
|
Instances
FromJSON DeletedDocuments Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser DeletedDocuments # parseJSONList :: Value -> Parser [DeletedDocuments] # | |
Show DeletedDocuments Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> DeletedDocuments -> ShowS # show :: DeletedDocuments -> String # showList :: [DeletedDocuments] -> ShowS # | |
Eq DeletedDocuments Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: DeletedDocuments -> DeletedDocuments -> Bool # (/=) :: DeletedDocuments -> DeletedDocuments -> Bool # |
data DeletedDocumentsRetries Source #
Constructors
DeletedDocumentsRetries | |
Fields |
Instances
FromJSON DeletedDocumentsRetries Source # | |
Show DeletedDocumentsRetries Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> DeletedDocumentsRetries -> ShowS # show :: DeletedDocumentsRetries -> String # showList :: [DeletedDocumentsRetries] -> ShowS # | |
Eq DeletedDocumentsRetries Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: DeletedDocumentsRetries -> DeletedDocumentsRetries -> Bool # (/=) :: DeletedDocumentsRetries -> DeletedDocumentsRetries -> Bool # |
data BulkOperation Source #
BulkOperation
is a sum type for expressing the four kinds of bulk
operation index, create, delete, and update. BulkIndex
behaves like an
"upsert", BulkCreate
will fail if a document already exists at the DocId.
Consult the Bulk API documentation
for further explanation.
Warning: Bulk operations suffixed with Auto
rely on Elasticsearch to
generate the id. Often, people use auto-generated identifiers when
Elasticsearch is the only place that their data is stored. Do not let
Elasticsearch be the only place your data is stored. It does not guarantee
durability, and it may silently discard data.
This issue is
discussed further on github.
Constructors
BulkIndex IndexName DocId Value | Create the document, replacing it if it already exists. |
BulkIndexAuto IndexName Value | Create a document with an autogenerated id. |
BulkIndexEncodingAuto IndexName Encoding | Create a document with an autogenerated id. Use fast JSON encoding. |
BulkCreate IndexName DocId Value | Create a document, failing if it already exists. |
BulkCreateEncoding IndexName DocId Encoding | Create a document, failing if it already exists. Use fast JSON encoding. |
BulkDelete IndexName DocId | Delete the document |
BulkUpdate IndexName DocId Value | Update the document, merging the new value with the existing one. |
BulkUpsert IndexName DocId UpsertPayload [UpsertActionMetadata] | Update the document if it already exists, otherwise insert it. |
Instances
Show BulkOperation Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Bulk Methods showsPrec :: Int -> BulkOperation -> ShowS # show :: BulkOperation -> String # showList :: [BulkOperation] -> ShowS # | |
Eq BulkOperation Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Bulk Methods (==) :: BulkOperation -> BulkOperation -> Bool # (/=) :: BulkOperation -> BulkOperation -> Bool # |
data UpsertActionMetadata Source #
Constructors
UA_RetryOnConflict Int | |
UA_Version Int |
Instances
Show UpsertActionMetadata Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Bulk Methods showsPrec :: Int -> UpsertActionMetadata -> ShowS # show :: UpsertActionMetadata -> String # showList :: [UpsertActionMetadata] -> ShowS # | |
Eq UpsertActionMetadata Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Bulk Methods (==) :: UpsertActionMetadata -> UpsertActionMetadata -> Bool # (/=) :: UpsertActionMetadata -> UpsertActionMetadata -> Bool # |
data UpsertPayload Source #
Instances
Show UpsertPayload Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Bulk Methods showsPrec :: Int -> UpsertPayload -> ShowS # show :: UpsertPayload -> String # showList :: [UpsertPayload] -> ShowS # | |
Eq UpsertPayload Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Bulk Methods (==) :: UpsertPayload -> UpsertPayload -> Bool # (/=) :: UpsertPayload -> UpsertPayload -> Bool # |
data BulkResponse Source #
Constructors
BulkResponse | |
Fields
|
Instances
FromJSON BulkResponse Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Bulk | |
Show BulkResponse Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Bulk Methods showsPrec :: Int -> BulkResponse -> ShowS # show :: BulkResponse -> String # showList :: [BulkResponse] -> ShowS # | |
Eq BulkResponse Source # | |
data BulkActionItem Source #
Constructors
BulkActionItem | |
Fields
|
Instances
FromJSON BulkActionItem Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Bulk Methods parseJSON :: Value -> Parser BulkActionItem # parseJSONList :: Value -> Parser [BulkActionItem] # | |
Show BulkActionItem Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Bulk Methods showsPrec :: Int -> BulkActionItem -> ShowS # show :: BulkActionItem -> String # showList :: [BulkActionItem] -> ShowS # | |
Eq BulkActionItem Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Bulk Methods (==) :: BulkActionItem -> BulkActionItem -> Bool # (/=) :: BulkActionItem -> BulkActionItem -> Bool # |
Constructors
BulkItem | |
newtype CountQuery Source #
Constructors
CountQuery | |
Fields
|
Instances
ToJSON CountQuery Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Count Methods toJSON :: CountQuery -> Value # toEncoding :: CountQuery -> Encoding # toJSONList :: [CountQuery] -> Value # toEncodingList :: [CountQuery] -> Encoding # omitField :: CountQuery -> Bool # | |
Show CountQuery Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Count Methods showsPrec :: Int -> CountQuery -> ShowS # show :: CountQuery -> String # showList :: [CountQuery] -> ShowS # | |
Eq CountQuery Source # | |
data CountResponse Source #
Constructors
CountResponse | |
Fields
|
Instances
FromJSON CountResponse Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Count Methods parseJSON :: Value -> Parser CountResponse # parseJSONList :: Value -> Parser [CountResponse] # | |
Show CountResponse Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Count Methods showsPrec :: Int -> CountResponse -> ShowS # show :: CountResponse -> String # showList :: [CountResponse] -> ShowS # | |
Eq CountResponse Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Count Methods (==) :: CountResponse -> CountResponse -> Bool # (/=) :: CountResponse -> CountResponse -> Bool # |
data CountShards Source #
Constructors
CountShards | |
Instances
FromJSON CountShards Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Count | |
Show CountShards Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Count Methods showsPrec :: Int -> CountShards -> ShowS # show :: CountShards -> String # showList :: [CountShards] -> ShowS # | |
Eq CountShards Source # | |
data AliasRouting Source #
Constructors
AllAliasRouting RoutingValue | |
GranularAliasRouting (Maybe SearchAliasRouting) (Maybe IndexAliasRouting) |
Instances
FromJSON AliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices | |
ToJSON AliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: AliasRouting -> Value # toEncoding :: AliasRouting -> Encoding # toJSONList :: [AliasRouting] -> Value # toEncodingList :: [AliasRouting] -> Encoding # omitField :: AliasRouting -> Bool # | |
Show AliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> AliasRouting -> ShowS # show :: AliasRouting -> String # showList :: [AliasRouting] -> ShowS # | |
Eq AliasRouting Source # | |
data AllocationPolicy Source #
Constructors
AllocAll | Allows shard allocation for all shards. |
AllocPrimaries | Allows shard allocation only for primary shards. |
AllocNewPrimaries | Allows shard allocation only for primary shards for new indices. |
AllocNone | No shard allocation is allowed |
Instances
FromJSON AllocationPolicy Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods parseJSON :: Value -> Parser AllocationPolicy # parseJSONList :: Value -> Parser [AllocationPolicy] # | |||||
ToJSON AllocationPolicy Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: AllocationPolicy -> Value # toEncoding :: AllocationPolicy -> Encoding # toJSONList :: [AllocationPolicy] -> Value # toEncodingList :: [AllocationPolicy] -> Encoding # omitField :: AllocationPolicy -> Bool # | |||||
Generic AllocationPolicy Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Associated Types
Methods from :: AllocationPolicy -> Rep AllocationPolicy x # to :: Rep AllocationPolicy x -> AllocationPolicy # | |||||
Show AllocationPolicy Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> AllocationPolicy -> ShowS # show :: AllocationPolicy -> String # showList :: [AllocationPolicy] -> ShowS # | |||||
Eq AllocationPolicy Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: AllocationPolicy -> AllocationPolicy -> Bool # (/=) :: AllocationPolicy -> AllocationPolicy -> Bool # | |||||
type Rep AllocationPolicy Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices type Rep AllocationPolicy = D1 ('MetaData "AllocationPolicy" "Database.Bloodhound.Internal.Versions.Common.Types.Indices" "bloodhound-0.24.0.0-A3ENRGIPQhkGcPhIwxbIBM" 'False) ((C1 ('MetaCons "AllocAll" 'PrefixI 'False) (U1 :: Type -> Type) :+: C1 ('MetaCons "AllocPrimaries" 'PrefixI 'False) (U1 :: Type -> Type)) :+: (C1 ('MetaCons "AllocNewPrimaries" 'PrefixI 'False) (U1 :: Type -> Type) :+: C1 ('MetaCons "AllocNone" 'PrefixI 'False) (U1 :: Type -> Type))) |
data CompoundFormat Source #
Constructors
CompoundFileFormat Bool | |
MergeSegmentVsTotalIndex Double | percentage between 0 and 1 where 0 is false, 1 is true |
Instances
FromJSON CompoundFormat Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods parseJSON :: Value -> Parser CompoundFormat # parseJSONList :: Value -> Parser [CompoundFormat] # | |||||
ToJSON CompoundFormat Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: CompoundFormat -> Value # toEncoding :: CompoundFormat -> Encoding # toJSONList :: [CompoundFormat] -> Value # toEncodingList :: [CompoundFormat] -> Encoding # omitField :: CompoundFormat -> Bool # | |||||
Generic CompoundFormat Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Associated Types
Methods from :: CompoundFormat -> Rep CompoundFormat x # to :: Rep CompoundFormat x -> CompoundFormat # | |||||
Show CompoundFormat Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> CompoundFormat -> ShowS # show :: CompoundFormat -> String # showList :: [CompoundFormat] -> ShowS # | |||||
Eq CompoundFormat Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: CompoundFormat -> CompoundFormat -> Bool # (/=) :: CompoundFormat -> CompoundFormat -> Bool # | |||||
type Rep CompoundFormat Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices type Rep CompoundFormat = D1 ('MetaData "CompoundFormat" "Database.Bloodhound.Internal.Versions.Common.Types.Indices" "bloodhound-0.24.0.0-A3ENRGIPQhkGcPhIwxbIBM" 'False) (C1 ('MetaCons "CompoundFileFormat" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bool)) :+: C1 ('MetaCons "MergeSegmentVsTotalIndex" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Double))) |
data Compression Source #
Constructors
CompressionDefault | Compress with LZ4 |
CompressionBest | Compress with DEFLATE. Elastic blogs that this can reduce disk use by 15%-25%. |
Instances
FromJSON Compression Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices | |||||
ToJSON Compression Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: Compression -> Value # toEncoding :: Compression -> Encoding # toJSONList :: [Compression] -> Value # toEncodingList :: [Compression] -> Encoding # omitField :: Compression -> Bool # | |||||
Generic Compression Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Associated Types
| |||||
Show Compression Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> Compression -> ShowS # show :: Compression -> String # showList :: [Compression] -> ShowS # | |||||
Eq Compression Source # | |||||
type Rep Compression Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices type Rep Compression = D1 ('MetaData "Compression" "Database.Bloodhound.Internal.Versions.Common.Types.Indices" "bloodhound-0.24.0.0-A3ENRGIPQhkGcPhIwxbIBM" 'False) (C1 ('MetaCons "CompressionDefault" 'PrefixI 'False) (U1 :: Type -> Type) :+: C1 ('MetaCons "CompressionBest" 'PrefixI 'False) (U1 :: Type -> Type)) |
Constructors
FSSimple | |
FSBuffered |
Instances
FromJSON FSType Source # | |||||
ToJSON FSType Source # | |||||
Generic FSType Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Associated Types
| |||||
Show FSType Source # | |||||
Eq FSType Source # | |||||
type Rep FSType Source # | |||||
newtype FieldDefinition Source #
Constructors
FieldDefinition | |
Instances
Show FieldDefinition Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> FieldDefinition -> ShowS # show :: FieldDefinition -> String # showList :: [FieldDefinition] -> ShowS # | |
Eq FieldDefinition Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: FieldDefinition -> FieldDefinition -> Bool # (/=) :: FieldDefinition -> FieldDefinition -> Bool # |
Constructors
GeoPointType | |
GeoShapeType | |
FloatType | |
IntegerType | |
LongType | |
ShortType | |
ByteType |
data ForceMergeIndexSettings Source #
ForceMergeIndexSettings
is used to configure index optimization. See
https://www.elastic.co/guide/en/elasticsearch/reference/current/indices-forcemerge.html
for more info.
Constructors
ForceMergeIndexSettings | |
Fields
|
Instances
Show ForceMergeIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> ForceMergeIndexSettings -> ShowS # show :: ForceMergeIndexSettings -> String # showList :: [ForceMergeIndexSettings] -> ShowS # | |
Eq ForceMergeIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: ForceMergeIndexSettings -> ForceMergeIndexSettings -> Bool # (/=) :: ForceMergeIndexSettings -> ForceMergeIndexSettings -> Bool # |
data IndexAlias Source #
Constructors
IndexAlias | |
Fields |
Instances
ToJSON IndexAlias Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: IndexAlias -> Value # toEncoding :: IndexAlias -> Encoding # toJSONList :: [IndexAlias] -> Value # toEncodingList :: [IndexAlias] -> Encoding # omitField :: IndexAlias -> Bool # | |
Show IndexAlias Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> IndexAlias -> ShowS # show :: IndexAlias -> String # showList :: [IndexAlias] -> ShowS # | |
Eq IndexAlias Source # | |
data IndexAliasAction Source #
Constructors
AddAlias IndexAlias IndexAliasCreate | |
RemoveAlias IndexAlias |
Instances
ToJSON IndexAliasAction Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: IndexAliasAction -> Value # toEncoding :: IndexAliasAction -> Encoding # toJSONList :: [IndexAliasAction] -> Value # toEncodingList :: [IndexAliasAction] -> Encoding # omitField :: IndexAliasAction -> Bool # | |
Show IndexAliasAction Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> IndexAliasAction -> ShowS # show :: IndexAliasAction -> String # showList :: [IndexAliasAction] -> ShowS # | |
Eq IndexAliasAction Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: IndexAliasAction -> IndexAliasAction -> Bool # (/=) :: IndexAliasAction -> IndexAliasAction -> Bool # |
data IndexAliasCreate Source #
Constructors
IndexAliasCreate | |
Fields |
Instances
FromJSON IndexAliasCreate Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods parseJSON :: Value -> Parser IndexAliasCreate # parseJSONList :: Value -> Parser [IndexAliasCreate] # | |
ToJSON IndexAliasCreate Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: IndexAliasCreate -> Value # toEncoding :: IndexAliasCreate -> Encoding # toJSONList :: [IndexAliasCreate] -> Value # toEncodingList :: [IndexAliasCreate] -> Encoding # omitField :: IndexAliasCreate -> Bool # | |
Show IndexAliasCreate Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> IndexAliasCreate -> ShowS # show :: IndexAliasCreate -> String # showList :: [IndexAliasCreate] -> ShowS # | |
Eq IndexAliasCreate Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: IndexAliasCreate -> IndexAliasCreate -> Bool # (/=) :: IndexAliasCreate -> IndexAliasCreate -> Bool # |
newtype IndexAliasRouting Source #
Constructors
IndexAliasRouting RoutingValue |
Instances
FromJSON IndexAliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods parseJSON :: Value -> Parser IndexAliasRouting # parseJSONList :: Value -> Parser [IndexAliasRouting] # | |
ToJSON IndexAliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: IndexAliasRouting -> Value # toEncoding :: IndexAliasRouting -> Encoding # toJSONList :: [IndexAliasRouting] -> Value # toEncodingList :: [IndexAliasRouting] -> Encoding # omitField :: IndexAliasRouting -> Bool # | |
Show IndexAliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> IndexAliasRouting -> ShowS # show :: IndexAliasRouting -> String # showList :: [IndexAliasRouting] -> ShowS # | |
Eq IndexAliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: IndexAliasRouting -> IndexAliasRouting -> Bool # (/=) :: IndexAliasRouting -> IndexAliasRouting -> Bool # |
data IndexAliasSummary Source #
IndexAliasSummary
is a summary of an index alias configured for a server.
Constructors
IndexAliasSummary | |
Instances
Show IndexAliasSummary Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> IndexAliasSummary -> ShowS # show :: IndexAliasSummary -> String # showList :: [IndexAliasSummary] -> ShowS # | |
Eq IndexAliasSummary Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: IndexAliasSummary -> IndexAliasSummary -> Bool # (/=) :: IndexAliasSummary -> IndexAliasSummary -> Bool # |
newtype IndexAliasesSummary Source #
Constructors
IndexAliasesSummary | |
Fields |
Instances
FromJSON IndexAliasesSummary Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods parseJSON :: Value -> Parser IndexAliasesSummary # parseJSONList :: Value -> Parser [IndexAliasesSummary] # | |
Show IndexAliasesSummary Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> IndexAliasesSummary -> ShowS # show :: IndexAliasesSummary -> String # showList :: [IndexAliasesSummary] -> ShowS # | |
Eq IndexAliasesSummary Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: IndexAliasesSummary -> IndexAliasesSummary -> Bool # (/=) :: IndexAliasesSummary -> IndexAliasesSummary -> Bool # |
data IndexDocumentSettings Source #
IndexDocumentSettings
are special settings supplied when indexing
a document. For the best backwards compatiblity when new fields are
added, you should probably prefer to start with defaultIndexDocumentSettings
Constructors
IndexDocumentSettings | |
Fields |
Instances
Show IndexDocumentSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> IndexDocumentSettings -> ShowS # show :: IndexDocumentSettings -> String # showList :: [IndexDocumentSettings] -> ShowS # | |
Eq IndexDocumentSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: IndexDocumentSettings -> IndexDocumentSettings -> Bool # (/=) :: IndexDocumentSettings -> IndexDocumentSettings -> Bool # |
data IndexMappingsLimits Source #
'IndexMappingsLimits is used to configure index's limits. https://www.elastic.co/guide/en/elasticsearch/reference/master/mapping-settings-limit.html
Constructors
IndexMappingsLimits | |
Instances
FromJSON IndexMappingsLimits Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods parseJSON :: Value -> Parser IndexMappingsLimits # parseJSONList :: Value -> Parser [IndexMappingsLimits] # | |||||
ToJSON IndexMappingsLimits Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: IndexMappingsLimits -> Value # toEncoding :: IndexMappingsLimits -> Encoding # toJSONList :: [IndexMappingsLimits] -> Value # toEncodingList :: [IndexMappingsLimits] -> Encoding # omitField :: IndexMappingsLimits -> Bool # | |||||
Generic IndexMappingsLimits Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Associated Types
Methods from :: IndexMappingsLimits -> Rep IndexMappingsLimits x # to :: Rep IndexMappingsLimits x -> IndexMappingsLimits # | |||||
Show IndexMappingsLimits Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> IndexMappingsLimits -> ShowS # show :: IndexMappingsLimits -> String # showList :: [IndexMappingsLimits] -> ShowS # | |||||
Eq IndexMappingsLimits Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: IndexMappingsLimits -> IndexMappingsLimits -> Bool # (/=) :: IndexMappingsLimits -> IndexMappingsLimits -> Bool # | |||||
type Rep IndexMappingsLimits Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices type Rep IndexMappingsLimits = D1 ('MetaData "IndexMappingsLimits" "Database.Bloodhound.Internal.Versions.Common.Types.Indices" "bloodhound-0.24.0.0-A3ENRGIPQhkGcPhIwxbIBM" 'False) (C1 ('MetaCons "IndexMappingsLimits" 'PrefixI 'True) ((S1 ('MetaSel ('Just "indexMappingsLimitDepth") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (Maybe Int)) :*: S1 ('MetaSel ('Just "indexMappingsLimitNestedFields") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (Maybe Int))) :*: (S1 ('MetaSel ('Just "indexMappingsLimitNestedObjects") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (Maybe Int)) :*: S1 ('MetaSel ('Just "indexMappingsLimitFieldNameLength") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (Maybe Int))))) |
newtype IndexPattern Source #
IndexPattern
represents a pattern which is matched against index names
Constructors
IndexPattern Text |
Instances
FromJSON IndexPattern Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices | |
ToJSON IndexPattern Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: IndexPattern -> Value # toEncoding :: IndexPattern -> Encoding # toJSONList :: [IndexPattern] -> Value # toEncodingList :: [IndexPattern] -> Encoding # omitField :: IndexPattern -> Bool # | |
Show IndexPattern Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> IndexPattern -> ShowS # show :: IndexPattern -> String # showList :: [IndexPattern] -> ShowS # | |
Eq IndexPattern Source # | |
data IndexSelection Source #
IndexSelection
is used for APIs which take a single index, a list of
indexes, or the special _all
index.
Constructors
IndexList (NonEmpty IndexName) | |
AllIndexes |
Instances
Show IndexSelection Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> IndexSelection -> ShowS # show :: IndexSelection -> String # showList :: [IndexSelection] -> ShowS # | |
Eq IndexSelection Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: IndexSelection -> IndexSelection -> Bool # (/=) :: IndexSelection -> IndexSelection -> Bool # |
data IndexSettings Source #
IndexSettings
is used to configure the shards and replicas when
you create an Elasticsearch Index.
http://www.elastic.co/guide/en/elasticsearch/reference/current/indices-create-index.html
Constructors
IndexSettings | |
Instances
FromJSON IndexSettings Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods parseJSON :: Value -> Parser IndexSettings # parseJSONList :: Value -> Parser [IndexSettings] # | |||||
ToJSON IndexSettings Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: IndexSettings -> Value # toEncoding :: IndexSettings -> Encoding # toJSONList :: [IndexSettings] -> Value # toEncodingList :: [IndexSettings] -> Encoding # omitField :: IndexSettings -> Bool # | |||||
Generic IndexSettings Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Associated Types
| |||||
Show IndexSettings Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> IndexSettings -> ShowS # show :: IndexSettings -> String # showList :: [IndexSettings] -> ShowS # | |||||
Eq IndexSettings Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: IndexSettings -> IndexSettings -> Bool # (/=) :: IndexSettings -> IndexSettings -> Bool # | |||||
type Rep IndexSettings Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices type Rep IndexSettings = D1 ('MetaData "IndexSettings" "Database.Bloodhound.Internal.Versions.Common.Types.Indices" "bloodhound-0.24.0.0-A3ENRGIPQhkGcPhIwxbIBM" 'False) (C1 ('MetaCons "IndexSettings" 'PrefixI 'True) (S1 ('MetaSel ('Just "indexShards") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 ShardCount) :*: (S1 ('MetaSel ('Just "indexReplicas") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 ReplicaCount) :*: S1 ('MetaSel ('Just "indexMappingsLimits") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 IndexMappingsLimits)))) |
data IndexSettingsSummary Source #
Constructors
IndexSettingsSummary | |
Instances
FromJSON IndexSettingsSummary Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods parseJSON :: Value -> Parser IndexSettingsSummary # parseJSONList :: Value -> Parser [IndexSettingsSummary] # | |
Show IndexSettingsSummary Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> IndexSettingsSummary -> ShowS # show :: IndexSettingsSummary -> String # showList :: [IndexSettingsSummary] -> ShowS # | |
Eq IndexSettingsSummary Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: IndexSettingsSummary -> IndexSettingsSummary -> Bool # (/=) :: IndexSettingsSummary -> IndexSettingsSummary -> Bool # |
data IndexTemplate Source #
An IndexTemplate
defines a template that will automatically be
applied to new indices created. The templates include both
IndexSettings
and mappings, and a simple IndexPattern
that
controls if the template will be applied to the index created.
Specify mappings as follows: [toJSON TweetMapping, ...]
https://www.elastic.co/guide/en/elasticsearch/reference/1.7/indices-templates.html
Constructors
IndexTemplate | |
Fields |
Instances
ToJSON IndexTemplate Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: IndexTemplate -> Value # toEncoding :: IndexTemplate -> Encoding # toJSONList :: [IndexTemplate] -> Value # toEncodingList :: [IndexTemplate] -> Encoding # omitField :: IndexTemplate -> Bool # |
data JoinRelation Source #
Instances
Show JoinRelation Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> JoinRelation -> ShowS # show :: JoinRelation -> String # showList :: [JoinRelation] -> ShowS # | |
Eq JoinRelation Source # | |
data MappingField Source #
Constructors
MappingField | |
Fields |
Instances
Show MappingField Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> MappingField -> ShowS # show :: MappingField -> String # showList :: [MappingField] -> ShowS # | |
Eq MappingField Source # | |
newtype NominalDiffTimeJSON Source #
Constructors
NominalDiffTimeJSON | |
Fields |
Instances
FromJSON NominalDiffTimeJSON Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods parseJSON :: Value -> Parser NominalDiffTimeJSON # parseJSONList :: Value -> Parser [NominalDiffTimeJSON] # | |
ToJSON NominalDiffTimeJSON Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: NominalDiffTimeJSON -> Value # toEncoding :: NominalDiffTimeJSON -> Encoding # toJSONList :: [NominalDiffTimeJSON] -> Value # toEncodingList :: [NominalDiffTimeJSON] -> Encoding # omitField :: NominalDiffTimeJSON -> Bool # |
data OpenCloseIndex Source #
OpenCloseIndex
is a sum type for opening and closing indices.
http://www.elastic.co/guide/en/elasticsearch/reference/current/indices-open-close.html
Constructors
OpenIndex | |
CloseIndex |
Instances
Show OpenCloseIndex Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> OpenCloseIndex -> ShowS # show :: OpenCloseIndex -> String # showList :: [OpenCloseIndex] -> ShowS # | |
Eq OpenCloseIndex Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: OpenCloseIndex -> OpenCloseIndex -> Bool # (/=) :: OpenCloseIndex -> OpenCloseIndex -> Bool # |
data ReplicaBounds Source #
Constructors
ReplicasBounded Int Int | |
ReplicasLowerBounded Int | |
ReplicasUnbounded |
Instances
FromJSON ReplicaBounds Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods parseJSON :: Value -> Parser ReplicaBounds # parseJSONList :: Value -> Parser [ReplicaBounds] # | |
ToJSON ReplicaBounds Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: ReplicaBounds -> Value # toEncoding :: ReplicaBounds -> Encoding # toJSONList :: [ReplicaBounds] -> Value # toEncodingList :: [ReplicaBounds] -> Encoding # omitField :: ReplicaBounds -> Bool # | |
Show ReplicaBounds Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> ReplicaBounds -> ShowS # show :: ReplicaBounds -> String # showList :: [ReplicaBounds] -> ShowS # | |
Eq ReplicaBounds Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: ReplicaBounds -> ReplicaBounds -> Bool # (/=) :: ReplicaBounds -> ReplicaBounds -> Bool # |
newtype RoutingValue Source #
Constructors
RoutingValue | |
Fields
|
Instances
FromJSON RoutingValue Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices | |
ToJSON RoutingValue Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: RoutingValue -> Value # toEncoding :: RoutingValue -> Encoding # toJSONList :: [RoutingValue] -> Value # toEncodingList :: [RoutingValue] -> Encoding # omitField :: RoutingValue -> Bool # | |
Show RoutingValue Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> RoutingValue -> ShowS # show :: RoutingValue -> String # showList :: [RoutingValue] -> ShowS # | |
Eq RoutingValue Source # | |
newtype SearchAliasRouting Source #
Constructors
SearchAliasRouting (NonEmpty RoutingValue) |
Instances
FromJSON SearchAliasRouting Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods parseJSON :: Value -> Parser SearchAliasRouting # parseJSONList :: Value -> Parser [SearchAliasRouting] # | |||||
ToJSON SearchAliasRouting Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: SearchAliasRouting -> Value # toEncoding :: SearchAliasRouting -> Encoding # toJSONList :: [SearchAliasRouting] -> Value # toEncodingList :: [SearchAliasRouting] -> Encoding # omitField :: SearchAliasRouting -> Bool # | |||||
Generic SearchAliasRouting Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Associated Types
Methods from :: SearchAliasRouting -> Rep SearchAliasRouting x # to :: Rep SearchAliasRouting x -> SearchAliasRouting # | |||||
Show SearchAliasRouting Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> SearchAliasRouting -> ShowS # show :: SearchAliasRouting -> String # showList :: [SearchAliasRouting] -> ShowS # | |||||
Eq SearchAliasRouting Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: SearchAliasRouting -> SearchAliasRouting -> Bool # (/=) :: SearchAliasRouting -> SearchAliasRouting -> Bool # | |||||
type Rep SearchAliasRouting Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices type Rep SearchAliasRouting = D1 ('MetaData "SearchAliasRouting" "Database.Bloodhound.Internal.Versions.Common.Types.Indices" "bloodhound-0.24.0.0-A3ENRGIPQhkGcPhIwxbIBM" 'True) (C1 ('MetaCons "SearchAliasRouting" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (NonEmpty RoutingValue)))) |
newtype TemplateName Source #
TemplateName
is used to describe which template to querycreatedelete
Constructors
TemplateName Text |
Instances
FromJSON TemplateName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices | |
ToJSON TemplateName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: TemplateName -> Value # toEncoding :: TemplateName -> Encoding # toJSONList :: [TemplateName] -> Value # toEncodingList :: [TemplateName] -> Encoding # omitField :: TemplateName -> Bool # | |
Show TemplateName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> TemplateName -> ShowS # show :: TemplateName -> String # showList :: [TemplateName] -> ShowS # | |
Eq TemplateName Source # | |
data UpdatableIndexSetting Source #
UpdatableIndexSetting
are settings which may be updated after an index is created.
https://www.elastic.co/guide/en/elasticsearch/reference/current/indices-update-settings.html
Constructors
NumberOfReplicas ReplicaCount | The number of replicas each shard has. |
AutoExpandReplicas ReplicaBounds | |
BlocksReadOnly Bool | Set to True to have the index read only. False to allow writes and metadata changes. |
BlocksRead Bool | Set to True to disable read operations against the index. |
BlocksWrite Bool | Set to True to disable write operations against the index. |
BlocksMetaData Bool | Set to True to disable metadata operations against the index. |
RefreshInterval NominalDiffTime | The async refresh interval of a shard |
IndexConcurrency Int | |
FailOnMergeFailure Bool | |
TranslogFlushThresholdOps Int | When to flush on operations. |
TranslogFlushThresholdSize Bytes | When to flush based on translog (bytes) size. |
TranslogFlushThresholdPeriod NominalDiffTime | When to flush based on a period of not flushing. |
TranslogDisableFlush Bool | Disables flushing. Note, should be set for a short interval and then enabled. |
CacheFilterMaxSize (Maybe Bytes) | The maximum size of filter cache (per segment in shard). |
CacheFilterExpire (Maybe NominalDiffTime) | The expire after access time for filter cache. |
GatewaySnapshotInterval NominalDiffTime | The gateway snapshot interval (only applies to shared gateways). |
RoutingAllocationInclude (NonEmpty NodeAttrFilter) | A node matching any rule will be allowed to host shards from the index. |
RoutingAllocationExclude (NonEmpty NodeAttrFilter) | A node matching any rule will NOT be allowed to host shards from the index. |
RoutingAllocationRequire (NonEmpty NodeAttrFilter) | Only nodes matching all rules will be allowed to host shards from the index. |
RoutingAllocationEnable AllocationPolicy | Enables shard allocation for a specific index. |
RoutingAllocationShardsPerNode ShardCount | Controls the total number of shards (replicas and primaries) allowed to be allocated on a single node. |
RecoveryInitialShards InitialShardCount | When using local gateway a particular shard is recovered only if there can be allocated quorum shards in the cluster. |
GCDeletes NominalDiffTime | |
TTLDisablePurge Bool | Disables temporarily the purge of expired docs. |
TranslogFSType FSType | |
CompressionSetting Compression | |
IndexCompoundFormat CompoundFormat | |
IndexCompoundOnFlush Bool | |
WarmerEnabled Bool | |
MappingTotalFieldsLimit Int | |
AnalysisSetting Analysis | Analysis is not a dynamic setting and can only be performed on a closed index. |
UnassignedNodeLeftDelayedTimeout NominalDiffTime | Sets a delay to the allocation of replica shards which become unassigned because a node has left, giving them chance to return. See https://www.elastic.co/guide/en/elasticsearch/reference/5.6/delayed-allocation.html |
Instances
FromJSON UpdatableIndexSetting Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods parseJSON :: Value -> Parser UpdatableIndexSetting # parseJSONList :: Value -> Parser [UpdatableIndexSetting] # | |||||
ToJSON UpdatableIndexSetting Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods toJSON :: UpdatableIndexSetting -> Value # toEncoding :: UpdatableIndexSetting -> Encoding # toJSONList :: [UpdatableIndexSetting] -> Value # toEncodingList :: [UpdatableIndexSetting] -> Encoding # omitField :: UpdatableIndexSetting -> Bool # | |||||
Generic UpdatableIndexSetting Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Associated Types
Methods from :: UpdatableIndexSetting -> Rep UpdatableIndexSetting x # to :: Rep UpdatableIndexSetting x -> UpdatableIndexSetting # | |||||
Show UpdatableIndexSetting Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods showsPrec :: Int -> UpdatableIndexSetting -> ShowS # show :: UpdatableIndexSetting -> String # showList :: [UpdatableIndexSetting] -> ShowS # | |||||
Eq UpdatableIndexSetting Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices Methods (==) :: UpdatableIndexSetting -> UpdatableIndexSetting -> Bool # (/=) :: UpdatableIndexSetting -> UpdatableIndexSetting -> Bool # | |||||
type Rep UpdatableIndexSetting Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Indices type Rep UpdatableIndexSetting = D1 ('MetaData "UpdatableIndexSetting" "Database.Bloodhound.Internal.Versions.Common.Types.Indices" "bloodhound-0.24.0.0-A3ENRGIPQhkGcPhIwxbIBM" 'False) (((((C1 ('MetaCons "NumberOfReplicas" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 ReplicaCount)) :+: C1 ('MetaCons "AutoExpandReplicas" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 ReplicaBounds))) :+: (C1 ('MetaCons "BlocksReadOnly" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bool)) :+: C1 ('MetaCons "BlocksRead" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bool)))) :+: ((C1 ('MetaCons "BlocksWrite" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bool)) :+: C1 ('MetaCons "BlocksMetaData" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bool))) :+: (C1 ('MetaCons "RefreshInterval" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 NominalDiffTime)) :+: C1 ('MetaCons "IndexConcurrency" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Int))))) :+: (((C1 ('MetaCons "FailOnMergeFailure" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bool)) :+: C1 ('MetaCons "TranslogFlushThresholdOps" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Int))) :+: (C1 ('MetaCons "TranslogFlushThresholdSize" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bytes)) :+: C1 ('MetaCons "TranslogFlushThresholdPeriod" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 NominalDiffTime)))) :+: ((C1 ('MetaCons "TranslogDisableFlush" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bool)) :+: C1 ('MetaCons "CacheFilterMaxSize" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (Maybe Bytes)))) :+: (C1 ('MetaCons "CacheFilterExpire" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (Maybe NominalDiffTime))) :+: C1 ('MetaCons "GatewaySnapshotInterval" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 NominalDiffTime)))))) :+: ((((C1 ('MetaCons "RoutingAllocationInclude" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (NonEmpty NodeAttrFilter))) :+: C1 ('MetaCons "RoutingAllocationExclude" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (NonEmpty NodeAttrFilter)))) :+: (C1 ('MetaCons "RoutingAllocationRequire" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (NonEmpty NodeAttrFilter))) :+: C1 ('MetaCons "RoutingAllocationEnable" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 AllocationPolicy)))) :+: ((C1 ('MetaCons "RoutingAllocationShardsPerNode" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 ShardCount)) :+: C1 ('MetaCons "RecoveryInitialShards" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 InitialShardCount))) :+: (C1 ('MetaCons "GCDeletes" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 NominalDiffTime)) :+: C1 ('MetaCons "TTLDisablePurge" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bool))))) :+: (((C1 ('MetaCons "TranslogFSType" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 FSType)) :+: C1 ('MetaCons "CompressionSetting" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Compression))) :+: (C1 ('MetaCons "IndexCompoundFormat" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 CompoundFormat)) :+: C1 ('MetaCons "IndexCompoundOnFlush" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bool)))) :+: ((C1 ('MetaCons "WarmerEnabled" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bool)) :+: C1 ('MetaCons "MappingTotalFieldsLimit" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Int))) :+: (C1 ('MetaCons "AnalysisSetting" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Analysis)) :+: C1 ('MetaCons "UnassignedNodeLeftDelayedTimeout" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 NominalDiffTime))))))) |
defaultForceMergeIndexSettings :: ForceMergeIndexSettings Source #
defaultForceMergeIndexSettings
implements the default settings that
Elasticsearch uses for index optimization. maxNumSegments
is Nothing,
onlyExpungeDeletes
is False, and flushAfterOptimize is True.
defaultIndexDocumentSettings :: IndexDocumentSettings Source #
Reasonable default settings. Chooses no version control and no parent.
defaultIndexSettings :: IndexSettings Source #
defaultIndexSettings
is an IndexSettings
with 3 shards and
2 replicas.
indexSettingsSummarySummaryUpdateableLens :: Lens' IndexSettingsSummary [UpdatableIndexSetting] Source #
data BoundTransportAddress Source #
Constructors
BoundTransportAddress | |
Fields
|
Instances
FromJSON BoundTransportAddress Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser BoundTransportAddress # parseJSONList :: Value -> Parser [BoundTransportAddress] # | |
Show BoundTransportAddress Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> BoundTransportAddress -> ShowS # show :: BoundTransportAddress -> String # showList :: [BoundTransportAddress] -> ShowS # | |
Eq BoundTransportAddress Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: BoundTransportAddress -> BoundTransportAddress -> Bool # (/=) :: BoundTransportAddress -> BoundTransportAddress -> Bool # |
Typically a 7 character hex string.
Instances
FromJSON BuildHash Source # | |
ToJSON BuildHash Source # | |
Show BuildHash Source # | |
Eq BuildHash Source # | |
Ord BuildHash Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes |
Constructors
CPUInfo | |
Fields
|
newtype ClusterName Source #
Constructors
ClusterName | |
Fields
|
Instances
FromJSON ClusterName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show ClusterName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> ClusterName -> ShowS # show :: ClusterName -> String # showList :: [ClusterName] -> ShowS # | |
Eq ClusterName Source # | |
Ord ClusterName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods compare :: ClusterName -> ClusterName -> Ordering # (<) :: ClusterName -> ClusterName -> Bool # (<=) :: ClusterName -> ClusterName -> Bool # (>) :: ClusterName -> ClusterName -> Bool # (>=) :: ClusterName -> ClusterName -> Bool # max :: ClusterName -> ClusterName -> ClusterName # min :: ClusterName -> ClusterName -> ClusterName # |
A quirky address format used throughout Elasticsearch. An example would be inet[/1.1.1.1:9200]. inet may be a placeholder for a FQDN.
Instances
FromJSON EsAddress Source # | |
Show EsAddress Source # | |
Eq EsAddress Source # | |
Ord EsAddress Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes |
newtype EsPassword Source #
Password type used for HTTP Basic authentication. See basicAuthHook
.
Constructors
EsPassword | |
Fields
|
Instances
Read EsPassword Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods readsPrec :: Int -> ReadS EsPassword # readList :: ReadS [EsPassword] # readPrec :: ReadPrec EsPassword # readListPrec :: ReadPrec [EsPassword] # | |
Show EsPassword Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> EsPassword -> ShowS # show :: EsPassword -> String # showList :: [EsPassword] -> ShowS # | |
Eq EsPassword Source # | |
newtype EsUsername Source #
Username type used for HTTP Basic authentication. See basicAuthHook
.
Constructors
EsUsername | |
Fields
|
Instances
Read EsUsername Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods readsPrec :: Int -> ReadS EsUsername # readList :: ReadS [EsUsername] # readPrec :: ReadPrec EsUsername # readListPrec :: ReadPrec [EsUsername] # | |
Show EsUsername Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> EsUsername -> ShowS # show :: EsUsername -> String # showList :: [EsUsername] -> ShowS # | |
Eq EsUsername Source # | |
newtype FullNodeId Source #
Unique, automatically-generated name assigned to nodes that are usually returned in node-oriented APIs.
Constructors
FullNodeId | |
Fields
|
Instances
FromJSON FullNodeId Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show FullNodeId Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> FullNodeId -> ShowS # show :: FullNodeId -> String # showList :: [FullNodeId] -> ShowS # | |
Eq FullNodeId Source # | |
Ord FullNodeId Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods compare :: FullNodeId -> FullNodeId -> Ordering # (<) :: FullNodeId -> FullNodeId -> Bool # (<=) :: FullNodeId -> FullNodeId -> Bool # (>) :: FullNodeId -> FullNodeId -> Bool # (>=) :: FullNodeId -> FullNodeId -> Bool # max :: FullNodeId -> FullNodeId -> FullNodeId # min :: FullNodeId -> FullNodeId -> FullNodeId # |
data InitialShardCount Source #
Instances
FromJSON InitialShardCount Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser InitialShardCount # parseJSONList :: Value -> Parser [InitialShardCount] # | |||||
ToJSON InitialShardCount Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods toJSON :: InitialShardCount -> Value # toEncoding :: InitialShardCount -> Encoding # toJSONList :: [InitialShardCount] -> Value # toEncodingList :: [InitialShardCount] -> Encoding # omitField :: InitialShardCount -> Bool # | |||||
Generic InitialShardCount Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Associated Types
Methods from :: InitialShardCount -> Rep InitialShardCount x # to :: Rep InitialShardCount x -> InitialShardCount # | |||||
Show InitialShardCount Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> InitialShardCount -> ShowS # show :: InitialShardCount -> String # showList :: [InitialShardCount] -> ShowS # | |||||
Eq InitialShardCount Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: InitialShardCount -> InitialShardCount -> Bool # (/=) :: InitialShardCount -> InitialShardCount -> Bool # | |||||
type Rep InitialShardCount Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes type Rep InitialShardCount = D1 ('MetaData "InitialShardCount" "Database.Bloodhound.Internal.Versions.Common.Types.Nodes" "bloodhound-0.24.0.0-A3ENRGIPQhkGcPhIwxbIBM" 'False) ((C1 ('MetaCons "QuorumShards" 'PrefixI 'False) (U1 :: Type -> Type) :+: C1 ('MetaCons "QuorumMinus1Shards" 'PrefixI 'False) (U1 :: Type -> Type)) :+: (C1 ('MetaCons "FullShards" 'PrefixI 'False) (U1 :: Type -> Type) :+: (C1 ('MetaCons "FullMinus1Shards" 'PrefixI 'False) (U1 :: Type -> Type) :+: C1 ('MetaCons "ExplicitShards" 'PrefixI 'False) (S1 ('MetaSel ('Nothing :: Maybe Symbol) 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Int))))) |
data JVMBufferPoolStats Source #
Constructors
JVMBufferPoolStats | |
Instances
FromJSON JVMBufferPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser JVMBufferPoolStats # parseJSONList :: Value -> Parser [JVMBufferPoolStats] # | |
Show JVMBufferPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> JVMBufferPoolStats -> ShowS # show :: JVMBufferPoolStats -> String # showList :: [JVMBufferPoolStats] -> ShowS # | |
Eq JVMBufferPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: JVMBufferPoolStats -> JVMBufferPoolStats -> Bool # (/=) :: JVMBufferPoolStats -> JVMBufferPoolStats -> Bool # |
newtype JVMGCCollector Source #
Constructors
JVMGCCollector | |
Fields |
Instances
FromJSON JVMGCCollector Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser JVMGCCollector # parseJSONList :: Value -> Parser [JVMGCCollector] # | |
Show JVMGCCollector Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> JVMGCCollector -> ShowS # show :: JVMGCCollector -> String # showList :: [JVMGCCollector] -> ShowS # | |
Eq JVMGCCollector Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: JVMGCCollector -> JVMGCCollector -> Bool # (/=) :: JVMGCCollector -> JVMGCCollector -> Bool # |
data JVMGCStats Source #
Constructors
JVMGCStats | |
Instances
FromJSON JVMGCStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show JVMGCStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> JVMGCStats -> ShowS # show :: JVMGCStats -> String # showList :: [JVMGCStats] -> ShowS # | |
Eq JVMGCStats Source # | |
data JVMMemoryInfo Source #
Constructors
JVMMemoryInfo | |
Instances
FromJSON JVMMemoryInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser JVMMemoryInfo # parseJSONList :: Value -> Parser [JVMMemoryInfo] # | |
Show JVMMemoryInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> JVMMemoryInfo -> ShowS # show :: JVMMemoryInfo -> String # showList :: [JVMMemoryInfo] -> ShowS # | |
Eq JVMMemoryInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: JVMMemoryInfo -> JVMMemoryInfo -> Bool # (/=) :: JVMMemoryInfo -> JVMMemoryInfo -> Bool # |
newtype JVMMemoryPool Source #
Constructors
JVMMemoryPool | |
Fields |
Instances
FromJSON JVMMemoryPool Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser JVMMemoryPool # parseJSONList :: Value -> Parser [JVMMemoryPool] # | |
Show JVMMemoryPool Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> JVMMemoryPool -> ShowS # show :: JVMMemoryPool -> String # showList :: [JVMMemoryPool] -> ShowS # | |
Eq JVMMemoryPool Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: JVMMemoryPool -> JVMMemoryPool -> Bool # (/=) :: JVMMemoryPool -> JVMMemoryPool -> Bool # |
data JVMPoolStats Source #
Constructors
JVMPoolStats | |
Fields |
Instances
FromJSON JVMPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show JVMPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> JVMPoolStats -> ShowS # show :: JVMPoolStats -> String # showList :: [JVMPoolStats] -> ShowS # | |
Eq JVMPoolStats Source # | |
newtype JVMVersion Source #
We cannot parse JVM version numbers and we're not going to try.
Constructors
JVMVersion | |
Fields
|
Instances
FromJSON JVMVersion Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show JVMVersion Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> JVMVersion -> ShowS # show :: JVMVersion -> String # showList :: [JVMVersion] -> ShowS # | |
Eq JVMVersion Source # | |
Constructors
LoadAvgs | |
Fields
|
newtype MacAddress Source #
Constructors
MacAddress | |
Fields
|
Instances
FromJSON MacAddress Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show MacAddress Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> MacAddress -> ShowS # show :: MacAddress -> String # showList :: [MacAddress] -> ShowS # | |
Eq MacAddress Source # | |
Ord MacAddress Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods compare :: MacAddress -> MacAddress -> Ordering # (<) :: MacAddress -> MacAddress -> Bool # (<=) :: MacAddress -> MacAddress -> Bool # (>) :: MacAddress -> MacAddress -> Bool # (>=) :: MacAddress -> MacAddress -> Bool # max :: MacAddress -> MacAddress -> MacAddress # min :: MacAddress -> MacAddress -> MacAddress # |
newtype NetworkInterfaceName Source #
Constructors
NetworkInterfaceName | |
Fields |
Instances
FromJSON NetworkInterfaceName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NetworkInterfaceName # parseJSONList :: Value -> Parser [NetworkInterfaceName] # | |
Show NetworkInterfaceName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NetworkInterfaceName -> ShowS # show :: NetworkInterfaceName -> String # showList :: [NetworkInterfaceName] -> ShowS # | |
Eq NetworkInterfaceName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NetworkInterfaceName -> NetworkInterfaceName -> Bool # (/=) :: NetworkInterfaceName -> NetworkInterfaceName -> Bool # | |
Ord NetworkInterfaceName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods compare :: NetworkInterfaceName -> NetworkInterfaceName -> Ordering # (<) :: NetworkInterfaceName -> NetworkInterfaceName -> Bool # (<=) :: NetworkInterfaceName -> NetworkInterfaceName -> Bool # (>) :: NetworkInterfaceName -> NetworkInterfaceName -> Bool # (>=) :: NetworkInterfaceName -> NetworkInterfaceName -> Bool # max :: NetworkInterfaceName -> NetworkInterfaceName -> NetworkInterfaceName # min :: NetworkInterfaceName -> NetworkInterfaceName -> NetworkInterfaceName # |
data NodeAttrFilter Source #
Constructors
NodeAttrFilter | |
Fields |
Instances
Show NodeAttrFilter Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeAttrFilter -> ShowS # show :: NodeAttrFilter -> String # showList :: [NodeAttrFilter] -> ShowS # | |
Eq NodeAttrFilter Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeAttrFilter -> NodeAttrFilter -> Bool # (/=) :: NodeAttrFilter -> NodeAttrFilter -> Bool # | |
Ord NodeAttrFilter Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods compare :: NodeAttrFilter -> NodeAttrFilter -> Ordering # (<) :: NodeAttrFilter -> NodeAttrFilter -> Bool # (<=) :: NodeAttrFilter -> NodeAttrFilter -> Bool # (>) :: NodeAttrFilter -> NodeAttrFilter -> Bool # (>=) :: NodeAttrFilter -> NodeAttrFilter -> Bool # max :: NodeAttrFilter -> NodeAttrFilter -> NodeAttrFilter # min :: NodeAttrFilter -> NodeAttrFilter -> NodeAttrFilter # |
newtype NodeAttrName Source #
Constructors
NodeAttrName Text |
Instances
Show NodeAttrName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeAttrName -> ShowS # show :: NodeAttrName -> String # showList :: [NodeAttrName] -> ShowS # | |
Eq NodeAttrName Source # | |
Ord NodeAttrName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods compare :: NodeAttrName -> NodeAttrName -> Ordering # (<) :: NodeAttrName -> NodeAttrName -> Bool # (<=) :: NodeAttrName -> NodeAttrName -> Bool # (>) :: NodeAttrName -> NodeAttrName -> Bool # (>=) :: NodeAttrName -> NodeAttrName -> Bool # max :: NodeAttrName -> NodeAttrName -> NodeAttrName # min :: NodeAttrName -> NodeAttrName -> NodeAttrName # |
data NodeBreakerStats Source #
Constructors
NodeBreakerStats | |
Fields |
Instances
FromJSON NodeBreakerStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeBreakerStats # parseJSONList :: Value -> Parser [NodeBreakerStats] # | |
Show NodeBreakerStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeBreakerStats -> ShowS # show :: NodeBreakerStats -> String # showList :: [NodeBreakerStats] -> ShowS # | |
Eq NodeBreakerStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeBreakerStats -> NodeBreakerStats -> Bool # (/=) :: NodeBreakerStats -> NodeBreakerStats -> Bool # |
data NodeBreakersStats Source #
Constructors
NodeBreakersStats | |
Instances
FromJSON NodeBreakersStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeBreakersStats # parseJSONList :: Value -> Parser [NodeBreakersStats] # | |
Show NodeBreakersStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeBreakersStats -> ShowS # show :: NodeBreakersStats -> String # showList :: [NodeBreakersStats] -> ShowS # | |
Eq NodeBreakersStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeBreakersStats -> NodeBreakersStats -> Bool # (/=) :: NodeBreakersStats -> NodeBreakersStats -> Bool # |
data NodeDataPathStats Source #
Constructors
NodeDataPathStats | |
Fields
|
Instances
FromJSON NodeDataPathStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeDataPathStats # parseJSONList :: Value -> Parser [NodeDataPathStats] # | |
Show NodeDataPathStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeDataPathStats -> ShowS # show :: NodeDataPathStats -> String # showList :: [NodeDataPathStats] -> ShowS # | |
Eq NodeDataPathStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeDataPathStats -> NodeDataPathStats -> Bool # (/=) :: NodeDataPathStats -> NodeDataPathStats -> Bool # |
data NodeFSStats Source #
Constructors
NodeFSStats | |
Fields |
Instances
FromJSON NodeFSStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show NodeFSStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeFSStats -> ShowS # show :: NodeFSStats -> String # showList :: [NodeFSStats] -> ShowS # | |
Eq NodeFSStats Source # | |
data NodeFSTotalStats Source #
Constructors
NodeFSTotalStats | |
Fields
|
Instances
FromJSON NodeFSTotalStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeFSTotalStats # parseJSONList :: Value -> Parser [NodeFSTotalStats] # | |
Show NodeFSTotalStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeFSTotalStats -> ShowS # show :: NodeFSTotalStats -> String # showList :: [NodeFSTotalStats] -> ShowS # | |
Eq NodeFSTotalStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeFSTotalStats -> NodeFSTotalStats -> Bool # (/=) :: NodeFSTotalStats -> NodeFSTotalStats -> Bool # |
data NodeHTTPInfo Source #
Constructors
NodeHTTPInfo | |
Instances
FromJSON NodeHTTPInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show NodeHTTPInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeHTTPInfo -> ShowS # show :: NodeHTTPInfo -> String # showList :: [NodeHTTPInfo] -> ShowS # | |
Eq NodeHTTPInfo Source # | |
data NodeHTTPStats Source #
Constructors
NodeHTTPStats | |
Fields |
Instances
FromJSON NodeHTTPStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeHTTPStats # parseJSONList :: Value -> Parser [NodeHTTPStats] # | |
Show NodeHTTPStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeHTTPStats -> ShowS # show :: NodeHTTPStats -> String # showList :: [NodeHTTPStats] -> ShowS # | |
Eq NodeHTTPStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeHTTPStats -> NodeHTTPStats -> Bool # (/=) :: NodeHTTPStats -> NodeHTTPStats -> Bool # |
data NodeIndicesStats Source #
Constructors
NodeIndicesStats | |
Fields
|
Instances
FromJSON NodeIndicesStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeIndicesStats # parseJSONList :: Value -> Parser [NodeIndicesStats] # | |
Show NodeIndicesStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeIndicesStats -> ShowS # show :: NodeIndicesStats -> String # showList :: [NodeIndicesStats] -> ShowS # | |
Eq NodeIndicesStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeIndicesStats -> NodeIndicesStats -> Bool # (/=) :: NodeIndicesStats -> NodeIndicesStats -> Bool # |
Constructors
NodeInfo | |
Fields
|
data NodeJVMInfo Source #
Constructors
NodeJVMInfo | |
Fields
|
Instances
FromJSON NodeJVMInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show NodeJVMInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeJVMInfo -> ShowS # show :: NodeJVMInfo -> String # showList :: [NodeJVMInfo] -> ShowS # | |
Eq NodeJVMInfo Source # | |
data NodeJVMStats Source #
Constructors
NodeJVMStats | |
Fields
|
Instances
FromJSON NodeJVMStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show NodeJVMStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeJVMStats -> ShowS # show :: NodeJVMStats -> String # showList :: [NodeJVMStats] -> ShowS # | |
Eq NodeJVMStats Source # | |
data NodeNetworkInfo Source #
Constructors
NodeNetworkInfo | |
Instances
FromJSON NodeNetworkInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeNetworkInfo # parseJSONList :: Value -> Parser [NodeNetworkInfo] # | |
Show NodeNetworkInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeNetworkInfo -> ShowS # show :: NodeNetworkInfo -> String # showList :: [NodeNetworkInfo] -> ShowS # | |
Eq NodeNetworkInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeNetworkInfo -> NodeNetworkInfo -> Bool # (/=) :: NodeNetworkInfo -> NodeNetworkInfo -> Bool # |
data NodeNetworkInterface Source #
Constructors
NodeNetworkInterface | |
Instances
FromJSON NodeNetworkInterface Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeNetworkInterface # parseJSONList :: Value -> Parser [NodeNetworkInterface] # | |
Show NodeNetworkInterface Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeNetworkInterface -> ShowS # show :: NodeNetworkInterface -> String # showList :: [NodeNetworkInterface] -> ShowS # | |
Eq NodeNetworkInterface Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeNetworkInterface -> NodeNetworkInterface -> Bool # (/=) :: NodeNetworkInterface -> NodeNetworkInterface -> Bool # |
data NodeNetworkStats Source #
Constructors
NodeNetworkStats | |
Instances
FromJSON NodeNetworkStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeNetworkStats # parseJSONList :: Value -> Parser [NodeNetworkStats] # | |
Show NodeNetworkStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeNetworkStats -> ShowS # show :: NodeNetworkStats -> String # showList :: [NodeNetworkStats] -> ShowS # | |
Eq NodeNetworkStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeNetworkStats -> NodeNetworkStats -> Bool # (/=) :: NodeNetworkStats -> NodeNetworkStats -> Bool # |
data NodeOSInfo Source #
Constructors
NodeOSInfo | |
Fields |
Instances
FromJSON NodeOSInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show NodeOSInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeOSInfo -> ShowS # show :: NodeOSInfo -> String # showList :: [NodeOSInfo] -> ShowS # | |
Eq NodeOSInfo Source # | |
data NodeOSStats Source #
Constructors
NodeOSStats | |
Fields |
Instances
FromJSON NodeOSStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show NodeOSStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeOSStats -> ShowS # show :: NodeOSStats -> String # showList :: [NodeOSStats] -> ShowS # | |
Eq NodeOSStats Source # | |
data NodePluginInfo Source #
Constructors
NodePluginInfo | |
Fields
|
Instances
FromJSON NodePluginInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodePluginInfo # parseJSONList :: Value -> Parser [NodePluginInfo] # | |
Show NodePluginInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodePluginInfo -> ShowS # show :: NodePluginInfo -> String # showList :: [NodePluginInfo] -> ShowS # | |
Eq NodePluginInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodePluginInfo -> NodePluginInfo -> Bool # (/=) :: NodePluginInfo -> NodePluginInfo -> Bool # |
data NodeProcessInfo Source #
Constructors
NodeProcessInfo | |
Instances
FromJSON NodeProcessInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeProcessInfo # parseJSONList :: Value -> Parser [NodeProcessInfo] # | |
Show NodeProcessInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeProcessInfo -> ShowS # show :: NodeProcessInfo -> String # showList :: [NodeProcessInfo] -> ShowS # | |
Eq NodeProcessInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeProcessInfo -> NodeProcessInfo -> Bool # (/=) :: NodeProcessInfo -> NodeProcessInfo -> Bool # |
data NodeProcessStats Source #
Constructors
NodeProcessStats | |
Instances
FromJSON NodeProcessStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeProcessStats # parseJSONList :: Value -> Parser [NodeProcessStats] # | |
Show NodeProcessStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeProcessStats -> ShowS # show :: NodeProcessStats -> String # showList :: [NodeProcessStats] -> ShowS # | |
Eq NodeProcessStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeProcessStats -> NodeProcessStats -> Bool # (/=) :: NodeProcessStats -> NodeProcessStats -> Bool # |
data NodeSelection Source #
NodeSelection
is used for most cluster APIs. See here for more details.
Constructors
LocalNode | Whatever node receives this request |
NodeList (NonEmpty NodeSelector) | |
AllNodes |
Instances
Show NodeSelection Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeSelection -> ShowS # show :: NodeSelection -> String # showList :: [NodeSelection] -> ShowS # | |
Eq NodeSelection Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeSelection -> NodeSelection -> Bool # (/=) :: NodeSelection -> NodeSelection -> Bool # |
data NodeSelector Source #
An exact match or pattern to identify a node. Note that All of these options support wildcarding, so your node name, server, attr name can all contain * characters to be a fuzzy match.
Constructors
NodeByName NodeName | |
NodeByFullNodeId FullNodeId | |
NodeByHost Server | e.g. 10.0.0.1 or even 10.0.0.* |
NodeByAttribute NodeAttrName Text | NodeAttrName can be a pattern, e.g. rack*. The value can too. |
Instances
Show NodeSelector Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeSelector -> ShowS # show :: NodeSelector -> String # showList :: [NodeSelector] -> ShowS # | |
Eq NodeSelector Source # | |
Constructors
NodeStats | |
Fields
|
data NodeThreadPoolInfo Source #
Constructors
NodeThreadPoolInfo | |
Instances
FromJSON NodeThreadPoolInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeThreadPoolInfo # parseJSONList :: Value -> Parser [NodeThreadPoolInfo] # | |
Show NodeThreadPoolInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeThreadPoolInfo -> ShowS # show :: NodeThreadPoolInfo -> String # showList :: [NodeThreadPoolInfo] -> ShowS # | |
Eq NodeThreadPoolInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeThreadPoolInfo -> NodeThreadPoolInfo -> Bool # (/=) :: NodeThreadPoolInfo -> NodeThreadPoolInfo -> Bool # |
data NodeThreadPoolStats Source #
Constructors
NodeThreadPoolStats | |
Instances
FromJSON NodeThreadPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeThreadPoolStats # parseJSONList :: Value -> Parser [NodeThreadPoolStats] # | |
Show NodeThreadPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeThreadPoolStats -> ShowS # show :: NodeThreadPoolStats -> String # showList :: [NodeThreadPoolStats] -> ShowS # | |
Eq NodeThreadPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeThreadPoolStats -> NodeThreadPoolStats -> Bool # (/=) :: NodeThreadPoolStats -> NodeThreadPoolStats -> Bool # |
data NodeTransportInfo Source #
Constructors
NodeTransportInfo | |
Instances
FromJSON NodeTransportInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeTransportInfo # parseJSONList :: Value -> Parser [NodeTransportInfo] # | |
Show NodeTransportInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeTransportInfo -> ShowS # show :: NodeTransportInfo -> String # showList :: [NodeTransportInfo] -> ShowS # | |
Eq NodeTransportInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeTransportInfo -> NodeTransportInfo -> Bool # (/=) :: NodeTransportInfo -> NodeTransportInfo -> Bool # |
data NodeTransportStats Source #
Constructors
NodeTransportStats | |
Fields |
Instances
FromJSON NodeTransportStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser NodeTransportStats # parseJSONList :: Value -> Parser [NodeTransportStats] # | |
Show NodeTransportStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodeTransportStats -> ShowS # show :: NodeTransportStats -> String # showList :: [NodeTransportStats] -> ShowS # | |
Eq NodeTransportStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: NodeTransportStats -> NodeTransportStats -> Bool # (/=) :: NodeTransportStats -> NodeTransportStats -> Bool # |
Constructors
NodesInfo | |
Fields
|
data NodesStats Source #
Constructors
NodesStats | |
Fields |
Instances
FromJSON NodesStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show NodesStats Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> NodesStats -> ShowS # show :: NodesStats -> String # showList :: [NodesStats] -> ShowS # | |
Eq NodesStats Source # | |
newtype PluginName Source #
Constructors
PluginName | |
Fields
|
Instances
FromJSON PluginName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show PluginName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> PluginName -> ShowS # show :: PluginName -> String # showList :: [PluginName] -> ShowS # | |
Eq PluginName Source # | |
Ord PluginName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods compare :: PluginName -> PluginName -> Ordering # (<) :: PluginName -> PluginName -> Bool # (<=) :: PluginName -> PluginName -> Bool # (>) :: PluginName -> PluginName -> Bool # (>=) :: PluginName -> PluginName -> Bool # max :: PluginName -> PluginName -> PluginName # min :: PluginName -> PluginName -> PluginName # |
data ShardResult Source #
Constructors
ShardResult | |
Fields
|
Instances
FromJSON ShardResult Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
ToJSON ShardResult Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods toJSON :: ShardResult -> Value # toEncoding :: ShardResult -> Encoding # toJSONList :: [ShardResult] -> Value # toEncodingList :: [ShardResult] -> Encoding # omitField :: ShardResult -> Bool # | |
Show ShardResult Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> ShardResult -> ShowS # show :: ShardResult -> String # showList :: [ShardResult] -> ShowS # | |
Eq ShardResult Source # | |
newtype ShardsResult Source #
Constructors
ShardsResult | |
Fields |
Instances
FromJSON ShardsResult Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes | |
Show ShardsResult Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> ShardsResult -> ShowS # show :: ShardsResult -> String # showList :: [ShardsResult] -> ShowS # | |
Eq ShardsResult Source # | |
data ThreadPool Source #
Constructors
ThreadPool | |
Fields |
Instances
Show ThreadPool Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> ThreadPool -> ShowS # show :: ThreadPool -> String # showList :: [ThreadPool] -> ShowS # | |
Eq ThreadPool Source # | |
data ThreadPoolSize Source #
Constructors
ThreadPoolBounded Int | |
ThreadPoolUnbounded |
Instances
FromJSON ThreadPoolSize Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser ThreadPoolSize # parseJSONList :: Value -> Parser [ThreadPoolSize] # | |
Show ThreadPoolSize Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> ThreadPoolSize -> ShowS # show :: ThreadPoolSize -> String # showList :: [ThreadPoolSize] -> ShowS # | |
Eq ThreadPoolSize Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: ThreadPoolSize -> ThreadPoolSize -> Bool # (/=) :: ThreadPoolSize -> ThreadPoolSize -> Bool # |
data ThreadPoolType Source #
Instances
FromJSON ThreadPoolType Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser ThreadPoolType # parseJSONList :: Value -> Parser [ThreadPoolType] # | |
Show ThreadPoolType Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> ThreadPoolType -> ShowS # show :: ThreadPoolType -> String # showList :: [ThreadPoolType] -> ShowS # | |
Eq ThreadPoolType Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: ThreadPoolType -> ThreadPoolType -> Bool # (/=) :: ThreadPoolType -> ThreadPoolType -> Bool # |
newtype VersionNumber Source #
Traditional software versioning number
Constructors
VersionNumber | |
Fields |
Instances
FromJSON VersionNumber Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods parseJSON :: Value -> Parser VersionNumber # parseJSONList :: Value -> Parser [VersionNumber] # | |
ToJSON VersionNumber Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods toJSON :: VersionNumber -> Value # toEncoding :: VersionNumber -> Encoding # toJSONList :: [VersionNumber] -> Value # toEncodingList :: [VersionNumber] -> Encoding # omitField :: VersionNumber -> Bool # | |
Show VersionNumber Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods showsPrec :: Int -> VersionNumber -> ShowS # show :: VersionNumber -> String # showList :: [VersionNumber] -> ShowS # | |
Eq VersionNumber Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods (==) :: VersionNumber -> VersionNumber -> Bool # (/=) :: VersionNumber -> VersionNumber -> Bool # | |
Ord VersionNumber Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Nodes Methods compare :: VersionNumber -> VersionNumber -> Ordering # (<) :: VersionNumber -> VersionNumber -> Bool # (<=) :: VersionNumber -> VersionNumber -> Bool # (>) :: VersionNumber -> VersionNumber -> Bool # (>=) :: VersionNumber -> VersionNumber -> Bool # max :: VersionNumber -> VersionNumber -> VersionNumber # min :: VersionNumber -> VersionNumber -> VersionNumber # |
data FsSnapshotRepo Source #
A filesystem-based snapshot repo that ships with
Elasticsearch. This is an instance of SnapshotRepo
so it can be
used with updateSnapshotRepo
Constructors
FsSnapshotRepo | |
Fields
|
Instances
Generic FsSnapshotRepo Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Associated Types
Methods from :: FsSnapshotRepo -> Rep FsSnapshotRepo x # to :: Rep FsSnapshotRepo x -> FsSnapshotRepo # | |||||
Show FsSnapshotRepo Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> FsSnapshotRepo -> ShowS # show :: FsSnapshotRepo -> String # showList :: [FsSnapshotRepo] -> ShowS # | |||||
SnapshotRepo FsSnapshotRepo Source # | |||||
Eq FsSnapshotRepo Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: FsSnapshotRepo -> FsSnapshotRepo -> Bool # (/=) :: FsSnapshotRepo -> FsSnapshotRepo -> Bool # | |||||
type Rep FsSnapshotRepo Source # | |||||
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots type Rep FsSnapshotRepo = D1 ('MetaData "FsSnapshotRepo" "Database.Bloodhound.Internal.Versions.Common.Types.Snapshots" "bloodhound-0.24.0.0-A3ENRGIPQhkGcPhIwxbIBM" 'False) (C1 ('MetaCons "FsSnapshotRepo" 'PrefixI 'True) ((S1 ('MetaSel ('Just "fsrName") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 SnapshotRepoName) :*: (S1 ('MetaSel ('Just "fsrLocation") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 FilePath) :*: S1 ('MetaSel ('Just "fsrCompressMetadata") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bool))) :*: (S1 ('MetaSel ('Just "fsrChunkSize") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (Maybe Bytes)) :*: (S1 ('MetaSel ('Just "fsrMaxRestoreBytesPerSec") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (Maybe Bytes)) :*: S1 ('MetaSel ('Just "fsrMaxSnapshotBytesPerSec") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 (Maybe Bytes)))))) |
data GenericSnapshotRepo Source #
A generic representation of a snapshot repo. This is what gets
sent to and parsed from the server. For repo types enabled by
plugins that aren't exported by this library, consider making a
custom type which implements SnapshotRepo
. If it is a common repo
type, consider submitting a pull request to have it included in the
library proper
Constructors
GenericSnapshotRepo | |
Instances
Show GenericSnapshotRepo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> GenericSnapshotRepo -> ShowS # show :: GenericSnapshotRepo -> String # showList :: [GenericSnapshotRepo] -> ShowS # | |
SnapshotRepo GenericSnapshotRepo Source # | |
Eq GenericSnapshotRepo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: GenericSnapshotRepo -> GenericSnapshotRepo -> Bool # (/=) :: GenericSnapshotRepo -> GenericSnapshotRepo -> Bool # |
newtype GenericSnapshotRepoSettings Source #
Opaque representation of snapshot repo settings. Instances of
SnapshotRepo
will produce this.
Constructors
GenericSnapshotRepoSettings | |
Fields |
Instances
FromJSON GenericSnapshotRepoSettings Source # | |
ToJSON GenericSnapshotRepoSettings Source # | |
Show GenericSnapshotRepoSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> GenericSnapshotRepoSettings -> ShowS # show :: GenericSnapshotRepoSettings -> String # showList :: [GenericSnapshotRepoSettings] -> ShowS # | |
Eq GenericSnapshotRepoSettings Source # | |
newtype RRGroupRefNum Source #
A group number for regex matching. Only values from 1-9 are
supported. Construct with mkRRGroupRefNum
Constructors
RRGroupRefNum | |
Fields
|
Instances
Bounded RRGroupRefNum Source # | |
Show RRGroupRefNum Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> RRGroupRefNum -> ShowS # show :: RRGroupRefNum -> String # showList :: [RRGroupRefNum] -> ShowS # | |
Eq RRGroupRefNum Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: RRGroupRefNum -> RRGroupRefNum -> Bool # (/=) :: RRGroupRefNum -> RRGroupRefNum -> Bool # | |
Ord RRGroupRefNum Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods compare :: RRGroupRefNum -> RRGroupRefNum -> Ordering # (<) :: RRGroupRefNum -> RRGroupRefNum -> Bool # (<=) :: RRGroupRefNum -> RRGroupRefNum -> Bool # (>) :: RRGroupRefNum -> RRGroupRefNum -> Bool # (>=) :: RRGroupRefNum -> RRGroupRefNum -> Bool # max :: RRGroupRefNum -> RRGroupRefNum -> RRGroupRefNum # min :: RRGroupRefNum -> RRGroupRefNum -> RRGroupRefNum # |
newtype RestoreIndexSettings Source #
Index settings that can be overridden. The docs only mention you can update number of replicas, but there may be more. You definitely cannot override shard count.
Constructors
RestoreIndexSettings | |
Fields |
Instances
ToJSON RestoreIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods toJSON :: RestoreIndexSettings -> Value # toEncoding :: RestoreIndexSettings -> Encoding # toJSONList :: [RestoreIndexSettings] -> Value # toEncodingList :: [RestoreIndexSettings] -> Encoding # omitField :: RestoreIndexSettings -> Bool # | |
Show RestoreIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> RestoreIndexSettings -> ShowS # show :: RestoreIndexSettings -> String # showList :: [RestoreIndexSettings] -> ShowS # | |
Eq RestoreIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: RestoreIndexSettings -> RestoreIndexSettings -> Bool # (/=) :: RestoreIndexSettings -> RestoreIndexSettings -> Bool # |
newtype RestoreRenamePattern Source #
Regex-stype pattern, e.g. "index_(.+)" to match index names
Constructors
RestoreRenamePattern | |
Instances
ToJSON RestoreRenamePattern Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods toJSON :: RestoreRenamePattern -> Value # toEncoding :: RestoreRenamePattern -> Encoding # toJSONList :: [RestoreRenamePattern] -> Value # toEncodingList :: [RestoreRenamePattern] -> Encoding # omitField :: RestoreRenamePattern -> Bool # | |
Show RestoreRenamePattern Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> RestoreRenamePattern -> ShowS # show :: RestoreRenamePattern -> String # showList :: [RestoreRenamePattern] -> ShowS # | |
Eq RestoreRenamePattern Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: RestoreRenamePattern -> RestoreRenamePattern -> Bool # (/=) :: RestoreRenamePattern -> RestoreRenamePattern -> Bool # | |
Ord RestoreRenamePattern Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods compare :: RestoreRenamePattern -> RestoreRenamePattern -> Ordering # (<) :: RestoreRenamePattern -> RestoreRenamePattern -> Bool # (<=) :: RestoreRenamePattern -> RestoreRenamePattern -> Bool # (>) :: RestoreRenamePattern -> RestoreRenamePattern -> Bool # (>=) :: RestoreRenamePattern -> RestoreRenamePattern -> Bool # max :: RestoreRenamePattern -> RestoreRenamePattern -> RestoreRenamePattern # min :: RestoreRenamePattern -> RestoreRenamePattern -> RestoreRenamePattern # |
data RestoreRenameToken Source #
A single token in a index renaming scheme for a restore. These are concatenated into a string before being sent to Elasticsearch. Check out these Java docs to find out more if you're into that sort of thing.
Constructors
RRTLit Text | Just a literal string of characters |
RRSubWholeMatch | Equivalent to $0. The entire matched pattern, not any subgroup |
RRSubGroup RRGroupRefNum | A specific reference to a group number |
Instances
Show RestoreRenameToken Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> RestoreRenameToken -> ShowS # show :: RestoreRenameToken -> String # showList :: [RestoreRenameToken] -> ShowS # | |
Eq RestoreRenameToken Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: RestoreRenameToken -> RestoreRenameToken -> Bool # (/=) :: RestoreRenameToken -> RestoreRenameToken -> Bool # |
data SnapshotCreateSettings Source #
Constructors
SnapshotCreateSettings | |
Fields
|
Instances
Show SnapshotCreateSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotCreateSettings -> ShowS # show :: SnapshotCreateSettings -> String # showList :: [SnapshotCreateSettings] -> ShowS # | |
Eq SnapshotCreateSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: SnapshotCreateSettings -> SnapshotCreateSettings -> Bool # (/=) :: SnapshotCreateSettings -> SnapshotCreateSettings -> Bool # |
data SnapshotInfo Source #
General information about the state of a snapshot. Has some
redundancies with SnapshotStatus
Constructors
SnapshotInfo | |
Instances
FromJSON SnapshotInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots | |
Show SnapshotInfo Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotInfo -> ShowS # show :: SnapshotInfo -> String # showList :: [SnapshotInfo] -> ShowS # | |
Eq SnapshotInfo Source # | |
data SnapshotNodeVerification Source #
A node that has verified a snapshot
Constructors
SnapshotNodeVerification | |
Fields |
Instances
Show SnapshotNodeVerification Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotNodeVerification -> ShowS # show :: SnapshotNodeVerification -> String # showList :: [SnapshotNodeVerification] -> ShowS # | |
Eq SnapshotNodeVerification Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: SnapshotNodeVerification -> SnapshotNodeVerification -> Bool # (/=) :: SnapshotNodeVerification -> SnapshotNodeVerification -> Bool # |
data SnapshotPattern Source #
Either specifies an exact snapshot name or one with globs in it,
e.g. SnapPattern "foo*"
NOTE: Patterns are not supported on
ES < 1.7
Constructors
ExactSnap SnapshotName | |
SnapPattern Text |
Instances
Show SnapshotPattern Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotPattern -> ShowS # show :: SnapshotPattern -> String # showList :: [SnapshotPattern] -> ShowS # | |
Eq SnapshotPattern Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: SnapshotPattern -> SnapshotPattern -> Bool # (/=) :: SnapshotPattern -> SnapshotPattern -> Bool # |
class SnapshotRepo r where Source #
Law: fromGSnapshotRepo (toGSnapshotRepo r) == Right r
Methods
toGSnapshotRepo :: r -> GenericSnapshotRepo Source #
fromGSnapshotRepo :: GenericSnapshotRepo -> Either SnapshotRepoConversionError r Source #
data SnapshotRepoConversionError Source #
Constructors
RepoTypeMismatch SnapshotRepoType SnapshotRepoType | Expected type and actual type |
OtherRepoConversionError Text |
Instances
Exception SnapshotRepoConversionError Source # | |
Show SnapshotRepoConversionError Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotRepoConversionError -> ShowS # show :: SnapshotRepoConversionError -> String # showList :: [SnapshotRepoConversionError] -> ShowS # | |
Eq SnapshotRepoConversionError Source # | |
newtype SnapshotRepoName Source #
The unique name of a snapshot repository.
Constructors
SnapshotRepoName | |
Fields |
Instances
FromJSON SnapshotRepoName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods parseJSON :: Value -> Parser SnapshotRepoName # parseJSONList :: Value -> Parser [SnapshotRepoName] # | |
ToJSON SnapshotRepoName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods toJSON :: SnapshotRepoName -> Value # toEncoding :: SnapshotRepoName -> Encoding # toJSONList :: [SnapshotRepoName] -> Value # toEncodingList :: [SnapshotRepoName] -> Encoding # omitField :: SnapshotRepoName -> Bool # | |
Show SnapshotRepoName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotRepoName -> ShowS # show :: SnapshotRepoName -> String # showList :: [SnapshotRepoName] -> ShowS # | |
Eq SnapshotRepoName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: SnapshotRepoName -> SnapshotRepoName -> Bool # (/=) :: SnapshotRepoName -> SnapshotRepoName -> Bool # | |
Ord SnapshotRepoName Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods compare :: SnapshotRepoName -> SnapshotRepoName -> Ordering # (<) :: SnapshotRepoName -> SnapshotRepoName -> Bool # (<=) :: SnapshotRepoName -> SnapshotRepoName -> Bool # (>) :: SnapshotRepoName -> SnapshotRepoName -> Bool # (>=) :: SnapshotRepoName -> SnapshotRepoName -> Bool # max :: SnapshotRepoName -> SnapshotRepoName -> SnapshotRepoName # min :: SnapshotRepoName -> SnapshotRepoName -> SnapshotRepoName # |
data SnapshotRepoPattern Source #
Either specifies an exact repo name or one with globs in it,
e.g. RepoPattern "foo*"
NOTE: Patterns are not supported on ES < 1.7
Constructors
ExactRepo SnapshotRepoName | |
RepoPattern Text |
Instances
Show SnapshotRepoPattern Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotRepoPattern -> ShowS # show :: SnapshotRepoPattern -> String # showList :: [SnapshotRepoPattern] -> ShowS # | |
Eq SnapshotRepoPattern Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: SnapshotRepoPattern -> SnapshotRepoPattern -> Bool # (/=) :: SnapshotRepoPattern -> SnapshotRepoPattern -> Bool # |
data SnapshotRepoSelection Source #
Constructors
SnapshotRepoList (NonEmpty SnapshotRepoPattern) | |
AllSnapshotRepos |
Instances
Show SnapshotRepoSelection Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotRepoSelection -> ShowS # show :: SnapshotRepoSelection -> String # showList :: [SnapshotRepoSelection] -> ShowS # | |
Eq SnapshotRepoSelection Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: SnapshotRepoSelection -> SnapshotRepoSelection -> Bool # (/=) :: SnapshotRepoSelection -> SnapshotRepoSelection -> Bool # |
newtype SnapshotRepoType Source #
Constructors
SnapshotRepoType | |
Fields |
Instances
FromJSON SnapshotRepoType Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods parseJSON :: Value -> Parser SnapshotRepoType # parseJSONList :: Value -> Parser [SnapshotRepoType] # | |
ToJSON SnapshotRepoType Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods toJSON :: SnapshotRepoType -> Value # toEncoding :: SnapshotRepoType -> Encoding # toJSONList :: [SnapshotRepoType] -> Value # toEncodingList :: [SnapshotRepoType] -> Encoding # omitField :: SnapshotRepoType -> Bool # | |
Show SnapshotRepoType Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotRepoType -> ShowS # show :: SnapshotRepoType -> String # showList :: [SnapshotRepoType] -> ShowS # | |
Eq SnapshotRepoType Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: SnapshotRepoType -> SnapshotRepoType -> Bool # (/=) :: SnapshotRepoType -> SnapshotRepoType -> Bool # | |
Ord SnapshotRepoType Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods compare :: SnapshotRepoType -> SnapshotRepoType -> Ordering # (<) :: SnapshotRepoType -> SnapshotRepoType -> Bool # (<=) :: SnapshotRepoType -> SnapshotRepoType -> Bool # (>) :: SnapshotRepoType -> SnapshotRepoType -> Bool # (>=) :: SnapshotRepoType -> SnapshotRepoType -> Bool # max :: SnapshotRepoType -> SnapshotRepoType -> SnapshotRepoType # min :: SnapshotRepoType -> SnapshotRepoType -> SnapshotRepoType # |
newtype SnapshotRepoUpdateSettings Source #
Constructors
SnapshotRepoUpdateSettings | |
Fields
|
Instances
Show SnapshotRepoUpdateSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotRepoUpdateSettings -> ShowS # show :: SnapshotRepoUpdateSettings -> String # showList :: [SnapshotRepoUpdateSettings] -> ShowS # | |
Eq SnapshotRepoUpdateSettings Source # | |
data SnapshotRestoreSettings Source #
Constructors
SnapshotRestoreSettings | |
Fields
|
Instances
Show SnapshotRestoreSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotRestoreSettings -> ShowS # show :: SnapshotRestoreSettings -> String # showList :: [SnapshotRestoreSettings] -> ShowS # | |
Eq SnapshotRestoreSettings Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: SnapshotRestoreSettings -> SnapshotRestoreSettings -> Bool # (/=) :: SnapshotRestoreSettings -> SnapshotRestoreSettings -> Bool # |
data SnapshotSelection Source #
Constructors
SnapshotList (NonEmpty SnapshotPattern) | |
AllSnapshots |
Instances
Show SnapshotSelection Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotSelection -> ShowS # show :: SnapshotSelection -> String # showList :: [SnapshotSelection] -> ShowS # | |
Eq SnapshotSelection Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: SnapshotSelection -> SnapshotSelection -> Bool # (/=) :: SnapshotSelection -> SnapshotSelection -> Bool # |
data SnapshotShardFailure Source #
Constructors
SnapshotShardFailure | |
Instances
FromJSON SnapshotShardFailure Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods parseJSON :: Value -> Parser SnapshotShardFailure # parseJSONList :: Value -> Parser [SnapshotShardFailure] # | |
Show SnapshotShardFailure Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotShardFailure -> ShowS # show :: SnapshotShardFailure -> String # showList :: [SnapshotShardFailure] -> ShowS # | |
Eq SnapshotShardFailure Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: SnapshotShardFailure -> SnapshotShardFailure -> Bool # (/=) :: SnapshotShardFailure -> SnapshotShardFailure -> Bool # |
data SnapshotState Source #
Constructors
SnapshotInit | |
SnapshotStarted | |
SnapshotSuccess | |
SnapshotFailed | |
SnapshotAborted | |
SnapshotMissing | |
SnapshotWaiting |
Instances
FromJSON SnapshotState Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods parseJSON :: Value -> Parser SnapshotState # parseJSONList :: Value -> Parser [SnapshotState] # | |
Show SnapshotState Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotState -> ShowS # show :: SnapshotState -> String # showList :: [SnapshotState] -> ShowS # | |
Eq SnapshotState Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: SnapshotState -> SnapshotState -> Bool # (/=) :: SnapshotState -> SnapshotState -> Bool # |
newtype SnapshotVerification Source #
The result of running verifySnapshotRepo
.
Constructors
SnapshotVerification | |
Instances
FromJSON SnapshotVerification Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods parseJSON :: Value -> Parser SnapshotVerification # parseJSONList :: Value -> Parser [SnapshotVerification] # | |
Show SnapshotVerification Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods showsPrec :: Int -> SnapshotVerification -> ShowS # show :: SnapshotVerification -> String # showList :: [SnapshotVerification] -> ShowS # | |
Eq SnapshotVerification Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Snapshots Methods (==) :: SnapshotVerification -> SnapshotVerification -> Bool # (/=) :: SnapshotVerification -> SnapshotVerification -> Bool # |
defaultSnapshotCreateSettings :: SnapshotCreateSettings Source #
Reasonable defaults for snapshot creation
- snapWaitForCompletion False
- snapIndices Nothing
- snapIgnoreUnavailable False
- snapIncludeGlobalState True
- snapPartial False
defaultSnapshotRepoUpdateSettings :: SnapshotRepoUpdateSettings Source #
Reasonable defaults for repo creation/update
- repoUpdateVerify True
defaultSnapshotRestoreSettings :: SnapshotRestoreSettings Source #
Reasonable defaults for snapshot restores
- snapRestoreWaitForCompletion False
- snapRestoreIndices Nothing
- snapRestoreIgnoreUnavailable False
- snapRestoreIncludeGlobalState True
- snapRestoreRenamePattern Nothing
- snapRestoreRenameReplacement Nothing
- snapRestorePartial False
- snapRestoreIncludeAliases True
- snapRestoreIndexSettingsOverrides Nothing
- snapRestoreIgnoreIndexSettings Nothing
mkRRGroupRefNum :: Int -> Maybe RRGroupRefNum Source #
Only allows valid group number references (1-9).
snapshotRestoreSettingsRenamePatternLens :: Lens' SnapshotRestoreSettings (Maybe RestoreRenamePattern) Source #
snapshotRestoreSettingsRenameReplacementLens :: Lens' SnapshotRestoreSettings (Maybe (NonEmpty RestoreRenameToken)) Source #
snapshotRestoreSettingsIndexSettingsOverridesLens :: Lens' SnapshotRestoreSettings (Maybe RestoreIndexSettings) Source #
snapshotRestoreSettingsIgnoreIndexSettingsLens :: Lens' SnapshotRestoreSettings (Maybe (NonEmpty Text)) Source #
restoreIndexSettingsOverrideReplicasLens :: Lens' RestoreIndexSettings (Maybe ReplicaCount) Source #
data TimeInterval Source #
Instances
Read TimeInterval Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Units Methods readsPrec :: Int -> ReadS TimeInterval # readList :: ReadS [TimeInterval] # | |
Show TimeInterval Source # | |
Defined in Database.Bloodhound.Internal.Versions.Common.Types.Units Methods showsPrec :: Int -> TimeInterval -> ShowS # show :: TimeInterval -> String # showList :: [TimeInterval] -> ShowS # | |
Eq TimeInterval Source # | |
parseStringInterval :: (Monad m, MonadFail m) => String -> m NominalDiffTime Source #
newtype BH (m :: Type -> Type) a Source #
Basic BH implementation
Instances
MonadTrans BH Source # | |||||
Defined in Database.Bloodhound.Client.Cluster | |||||
MonadReader r m => MonadReader r (BH m) Source # | |||||
MonadState s m => MonadState s (BH m) Source # | |||||
MonadWriter w m => MonadWriter w (BH m) Source # | |||||
MonadFail m => MonadFail (BH m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster | |||||
MonadFix m => MonadFix (BH m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster | |||||
MonadIO m => MonadIO (BH m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster | |||||
Monad m => Alternative (BH m) Source # | |||||
Monad m => Applicative (BH m) Source # | |||||
Functor m => Functor (BH m) Source # | |||||
Monad m => Monad (BH m) Source # | |||||
Monad m => MonadPlus (BH m) Source # | |||||
(Functor m, Applicative m, MonadIO m, MonadCatch m, MonadThrow m) => MonadBH (BH m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster Associated Types
| |||||
MonadCatch m => MonadCatch (BH m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster | |||||
MonadMask m => MonadMask (BH m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster Methods mask :: HasCallStack => ((forall a. BH m a -> BH m a) -> BH m b) -> BH m b # uninterruptibleMask :: HasCallStack => ((forall a. BH m a -> BH m a) -> BH m b) -> BH m b # generalBracket :: HasCallStack => BH m a -> (a -> ExitCase b -> BH m c) -> (a -> BH m b) -> BH m (b, c) # | |||||
MonadThrow m => MonadThrow (BH m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster Methods throwM :: (HasCallStack, Exception e) => e -> BH m a # | |||||
type Backend (BH m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster |
Common environment for Elasticsearch calls. Connections will be pipelined according to the provided HTTP connection manager.
class (Functor m, Applicative m, MonadIO m, MonadCatch m) => MonadBH (m :: Type -> Type) where Source #
All API calls to Elasticsearch operate within
MonadBH
. The idea is that it can be easily embedded in your
own monad transformer stack. A default instance for a ReaderT and
alias BH
is provided for the simple case.
Methods
dispatch :: BHRequest contextualized body -> m (BHResponse contextualized body) Source #
tryEsError :: m a -> m (Either EsError a) Source #
throwEsError :: EsError -> m a Source #
Instances
(Functor m, Applicative m, MonadIO m, MonadCatch m, MonadThrow m) => MonadBH (BH m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster Associated Types
| |||||
MonadBH m => MonadBH (StaticBH backend m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster Associated Types
|
data BackendType Source #
Backend (i.e. implementation) the queries are ran against
Constructors
ElasticSearch7 | |
OpenSearch1 | |
OpenSearch2 | |
Dynamic | unknown, can be anything |
type WithBackend (backend :: BackendType) (m :: Type -> Type) = WithBackendType backend (Backend m) Source #
Helper for WithBackendType
type family WithBackendType (expected :: BackendType) (actual :: BackendType) where ... Source #
Best-effort, by-passed for Dynamic
, statically enforced implementation
Equations
WithBackendType e 'Dynamic = () | |
WithBackendType e a = e ~ a |
newtype StaticBH (backend :: BackendType) (m :: Type -> Type) a Source #
Statically-type backend.
It's also an useful wrapper for DerivingVia
Constructors
StaticBH | |
Fields
|
Instances
MonadReader r m => MonadReader r (StaticBH backend m) Source # | |||||
MonadState s m => MonadState s (StaticBH backend m) Source # | |||||
MonadWriter w m => MonadWriter w (StaticBH backend m) Source # | |||||
MonadTrans (StaticBH backend) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster | |||||
MonadFail m => MonadFail (StaticBH backend m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster | |||||
MonadFix m => MonadFix (StaticBH backend m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster | |||||
MonadIO m => MonadIO (StaticBH backend m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster | |||||
Alternative m => Alternative (StaticBH backend m) Source # | |||||
Applicative m => Applicative (StaticBH backend m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster Methods pure :: a -> StaticBH backend m a # (<*>) :: StaticBH backend m (a -> b) -> StaticBH backend m a -> StaticBH backend m b # liftA2 :: (a -> b -> c) -> StaticBH backend m a -> StaticBH backend m b -> StaticBH backend m c # (*>) :: StaticBH backend m a -> StaticBH backend m b -> StaticBH backend m b # (<*) :: StaticBH backend m a -> StaticBH backend m b -> StaticBH backend m a # | |||||
Functor m => Functor (StaticBH backend m) Source # | |||||
Monad m => Monad (StaticBH backend m) Source # | |||||
MonadPlus m => MonadPlus (StaticBH backend m) Source # | |||||
MonadBH m => MonadBH (StaticBH backend m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster Associated Types
| |||||
MonadCatch m => MonadCatch (StaticBH backend m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster | |||||
MonadMask m => MonadMask (StaticBH backend m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster Methods mask :: HasCallStack => ((forall a. StaticBH backend m a -> StaticBH backend m a) -> StaticBH backend m b) -> StaticBH backend m b # uninterruptibleMask :: HasCallStack => ((forall a. StaticBH backend m a -> StaticBH backend m a) -> StaticBH backend m b) -> StaticBH backend m b # generalBracket :: HasCallStack => StaticBH backend m a -> (a -> ExitCase b -> StaticBH backend m c) -> (a -> StaticBH backend m b) -> StaticBH backend m (b, c) # | |||||
MonadThrow m => MonadThrow (StaticBH backend m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster Methods throwM :: (HasCallStack, Exception e) => e -> StaticBH backend m a # | |||||
type Backend (StaticBH backend m) Source # | |||||
Defined in Database.Bloodhound.Client.Cluster |
data SBackendType (a :: BackendType) where Source #
Dependently-typed version of BackendType
Constructors
SElasticSearch7 :: SBackendType 'ElasticSearch7 | |
SOpenSearch1 :: SBackendType 'OpenSearch1 | |
SOpenSearch2 :: SBackendType 'OpenSearch2 |
mkBHEnv :: Server -> Manager -> BHEnv Source #
Create a BHEnv
with all optional fields defaulted. HTTP hook
will be a noop. You can use the exported fields to customize
it further, e.g.:
> (mkBHEnv myServer myManager) { bhRequestHook = customHook }
performBHRequest :: (MonadBH m, MonadThrow m, ParseBHResponse contextualized) => BHRequest contextualized a -> m a Source #
tryPerformBHRequest :: (MonadBH m, MonadThrow m, ParseBHResponse contextualized) => BHRequest contextualized a -> m (ParsedEsResponse a) Source #
unsafePerformBH :: forall (backend :: BackendType) m a. StaticBH backend m a -> m a Source #
Run a piece of code as-if we are on a given backend
withDynamicBH :: MonadBH m => BackendType -> (forall (backend :: BackendType). SBackendType backend -> StaticBH backend m a) -> m a Source #
Run an action given an actual backend