| Safe Haskell | Safe-Inferred |
|---|---|
| Language | Haskell2010 |
Database.Bloodhound.Internal.Client
Synopsis
- data BHEnv = BHEnv {}
- class (Functor m, Applicative m, MonadIO m) => MonadBH m where
- mkBHEnv :: Server -> Manager -> BHEnv
- newtype BH m a = BH {}
- runBH :: BHEnv -> BH m a -> m a
- data Version = Version {}
- newtype VersionNumber = VersionNumber {}
- data Status = Status {
- name :: Text
- cluster_name :: Text
- cluster_uuid :: Text
- version :: Version
- tagline :: Text
- data IndexSettings = IndexSettings {}
- defaultIndexSettings :: IndexSettings
- data IndexMappingsLimits = IndexMappingsLimits {}
- defaultIndexMappingsLimits :: IndexMappingsLimits
- data ForceMergeIndexSettings = ForceMergeIndexSettings {}
- defaultForceMergeIndexSettings :: ForceMergeIndexSettings
- 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
- attrFilterJSON :: NonEmpty NodeAttrFilter -> Value
- parseAttrFilter :: Value -> Parser (NonEmpty NodeAttrFilter)
- data ReplicaBounds
- data Compression
- newtype Bytes = Bytes Int
- gigabytes :: Int -> Bytes
- megabytes :: Int -> Bytes
- kilobytes :: Int -> Bytes
- data FSType
- data InitialShardCount
- data NodeAttrFilter = NodeAttrFilter {}
- newtype NodeAttrName = NodeAttrName Text
- data CompoundFormat
- newtype NominalDiffTimeJSON = NominalDiffTimeJSON {}
- data IndexSettingsSummary = IndexSettingsSummary {}
- parseSettings :: Object -> Parser [UpdatableIndexSetting]
- data OpenCloseIndex
- data FieldType
- newtype FieldDefinition = FieldDefinition {}
- data IndexTemplate = IndexTemplate {}
- data MappingField = MappingField {}
- newtype Mapping = Mapping {}
- data UpsertActionMetadata
- buildUpsertActionMetadata :: UpsertActionMetadata -> Pair
- data UpsertPayload
- data AllocationPolicy
- 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 IndexAlias = IndexAlias {}
- data IndexAliasAction
- data IndexAliasCreate = IndexAliasCreate {}
- data AliasRouting
- newtype SearchAliasRouting = SearchAliasRouting (NonEmpty RoutingValue)
- newtype IndexAliasRouting = IndexAliasRouting RoutingValue
- newtype RoutingValue = RoutingValue {
- routingValue :: Text
- newtype IndexAliasesSummary = IndexAliasesSummary {}
- data IndexAliasSummary = IndexAliasSummary {}
- data JoinRelation
- data IndexDocumentSettings = IndexDocumentSettings {}
- defaultIndexDocumentSettings :: IndexDocumentSettings
- data IndexSelection
- data NodeSelection
- data NodeSelector
- newtype TemplateName = TemplateName Text
- newtype IndexPattern = IndexPattern Text
- newtype EsUsername = EsUsername {
- esUsername :: Text
- newtype EsPassword = EsPassword {
- esPassword :: Text
- data SnapshotRepoSelection
- data SnapshotRepoPattern
- newtype SnapshotRepoName = SnapshotRepoName {}
- data GenericSnapshotRepo = GenericSnapshotRepo {}
- newtype SnapshotRepoType = SnapshotRepoType {}
- newtype GenericSnapshotRepoSettings = GenericSnapshotRepoSettings {}
- newtype SnapshotVerification = SnapshotVerification {}
- data SnapshotNodeVerification = SnapshotNodeVerification {}
- newtype FullNodeId = FullNodeId {
- fullNodeId :: Text
- newtype NodeName = NodeName {}
- newtype ClusterName = ClusterName {
- clusterName :: Text
- data NodesInfo = NodesInfo {}
- data NodesStats = NodesStats {}
- 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 NodeBreakersStats = NodeBreakersStats {}
- data NodeBreakerStats = NodeBreakerStats {}
- data NodeHTTPStats = NodeHTTPStats {}
- data NodeTransportStats = NodeTransportStats {}
- data NodeFSStats = NodeFSStats {}
- 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 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 NodeNetworkStats = NodeNetworkStats {}
- data NodeThreadPoolStats = NodeThreadPoolStats {}
- 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 JVMBufferPoolStats = JVMBufferPoolStats {}
- data JVMGCStats = JVMGCStats {}
- data JVMPoolStats = JVMPoolStats {}
- data NodeProcessStats = NodeProcessStats {}
- data NodeOSStats = NodeOSStats {}
- data LoadAvgs = LoadAvgs {}
- 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
- newtype EsAddress = EsAddress {}
- newtype BuildHash = BuildHash {}
- newtype PluginName = PluginName {
- pluginName :: Text
- 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 NodePluginInfo = NodePluginInfo {}
- data NodeHTTPInfo = NodeHTTPInfo {}
- data NodeTransportInfo = NodeTransportInfo {}
- data BoundTransportAddress = BoundTransportAddress {}
- data NodeNetworkInfo = NodeNetworkInfo {}
- newtype MacAddress = MacAddress {
- macAddress :: Text
- newtype NetworkInterfaceName = NetworkInterfaceName {}
- data NodeNetworkInterface = NodeNetworkInterface {}
- data ThreadPool = ThreadPool {}
- data NodeThreadPoolInfo = NodeThreadPoolInfo {}
- data ThreadPoolSize
- data ThreadPoolType
- data NodeJVMInfo = NodeJVMInfo {}
- newtype JVMVersion = JVMVersion {
- unJVMVersion :: Text
- data JVMMemoryInfo = JVMMemoryInfo {}
- newtype VMVersion = VMVersion {
- unVMVersion :: Text
- newtype JVMMemoryPool = JVMMemoryPool {}
- newtype JVMGCCollector = JVMGCCollector {}
- newtype PID = PID {}
- data NodeOSInfo = NodeOSInfo {}
- data CPUInfo = CPUInfo {
- cpuCacheSize :: Bytes
- cpuCoresPerSocket :: Int
- cpuTotalSockets :: Int
- cpuTotalCores :: Int
- cpuMHZ :: Int
- cpuModel :: Text
- cpuVendor :: Text
- data NodeProcessInfo = NodeProcessInfo {}
- data ShardResult = ShardResult {
- shardTotal :: Int
- shardsSuccessful :: Int
- shardsSkipped :: Int
- shardsFailed :: Int
- data SnapshotState
- 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)
- newtype SnapshotRepoUpdateSettings = SnapshotRepoUpdateSettings {}
- defaultSnapshotRepoUpdateSettings :: SnapshotRepoUpdateSettings
- data FsSnapshotRepo = FsSnapshotRepo {}
- parseRepo :: Parser a -> Either SnapshotRepoConversionError a
- fsRepoType :: SnapshotRepoType
- class SnapshotRepo r where
- data SnapshotRepoConversionError
- data SnapshotCreateSettings = SnapshotCreateSettings {}
- defaultSnapshotCreateSettings :: SnapshotCreateSettings
- data SnapshotSelection
- data SnapshotPattern
- data SnapshotInfo = SnapshotInfo {}
- data SnapshotShardFailure = SnapshotShardFailure {}
- newtype RestoreRenamePattern = RestoreRenamePattern {}
- data RestoreRenameToken
- newtype RRGroupRefNum = RRGroupRefNum {
- rrGroupRefNum :: Int
- mkRRGroupRefNum :: Int -> Maybe RRGroupRefNum
- defaultSnapshotRestoreSettings :: SnapshotRestoreSettings
- newtype RestoreIndexSettings = RestoreIndexSettings {}
- parseNodeStats :: FullNodeId -> Object -> Parser NodeStats
- parseNodeInfo :: FullNodeId -> Object -> Parser NodeInfo
- data TimeInterval
- data Interval
- parseStringInterval :: (Monad m, MonadFail m) => String -> m NominalDiffTime
Documentation
Common environment for Elasticsearch calls. Connections will be pipelined according to the provided HTTP connection manager.
Constructors
| BHEnv | |
class (Functor m, Applicative m, MonadIO m) => MonadBH m 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.
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 }Instances
Constructors
| Version | |
Fields | |
Instances
| FromJSON Version Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| ToJSON Version Source # | |
| Generic Version Source # | |
| Show Version Source # | |
| Eq Version Source # | |
| type Rep Version Source # | |
Defined in Database.Bloodhound.Internal.Client type Rep Version = D1 ('MetaData "Version" "Database.Bloodhound.Internal.Client" "bloodhound-0.22.0.0-VeHs1GCpNS1U7OiaGh4gE" 'False) (C1 ('MetaCons "Version" 'PrefixI 'True) ((S1 ('MetaSel ('Just "number") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 VersionNumber) :*: S1 ('MetaSel ('Just "build_hash") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 BuildHash)) :*: (S1 ('MetaSel ('Just "build_date") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 UTCTime) :*: (S1 ('MetaSel ('Just "build_snapshot") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 Bool) :*: S1 ('MetaSel ('Just "lucene_version") 'NoSourceUnpackedness 'NoSourceStrictness 'DecidedLazy) (Rec0 VersionNumber))))) | |
newtype VersionNumber Source #
Traditional software versioning number
Constructors
| VersionNumber | |
Fields | |
Instances
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
| |
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
defaultIndexSettings :: IndexSettings Source #
defaultIndexSettings is an IndexSettings with 3 shards and
2 replicas.
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
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.Client Methods showsPrec :: Int -> ForceMergeIndexSettings -> ShowS # show :: ForceMergeIndexSettings -> String # showList :: [ForceMergeIndexSettings] -> ShowS # | |
| Eq ForceMergeIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: ForceMergeIndexSettings -> ForceMergeIndexSettings -> Bool # (/=) :: ForceMergeIndexSettings -> ForceMergeIndexSettings -> Bool # | |
defaultForceMergeIndexSettings :: ForceMergeIndexSettings Source #
defaultForceMergeIndexSettings implements the default settings that
Elasticsearch uses for index optimization. maxNumSegments is Nothing,
onlyExpungeDeletes is False, and flushAfterOptimize is True.
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
parseAttrFilter :: Value -> Parser (NonEmpty NodeAttrFilter) Source #
data ReplicaBounds Source #
Constructors
| ReplicasBounded Int Int | |
| ReplicasLowerBounded Int | |
| ReplicasUnbounded |
Instances
| FromJSON ReplicaBounds Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser ReplicaBounds # parseJSONList :: Value -> Parser [ReplicaBounds] # | |
| ToJSON ReplicaBounds Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: ReplicaBounds -> Value # toEncoding :: ReplicaBounds -> Encoding # toJSONList :: [ReplicaBounds] -> Value # toEncodingList :: [ReplicaBounds] -> Encoding # omitField :: ReplicaBounds -> Bool # | |
| Show ReplicaBounds Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> ReplicaBounds -> ShowS # show :: ReplicaBounds -> String # showList :: [ReplicaBounds] -> ShowS # | |
| Eq ReplicaBounds Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: ReplicaBounds -> ReplicaBounds -> Bool # (/=) :: ReplicaBounds -> ReplicaBounds -> Bool # | |
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.Client | |
| ToJSON Compression Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: Compression -> Value # toEncoding :: Compression -> Encoding # toJSONList :: [Compression] -> Value # toEncodingList :: [Compression] -> Encoding # omitField :: Compression -> Bool # | |
| Generic Compression Source # | |
Defined in Database.Bloodhound.Internal.Client Associated Types type Rep Compression :: Type -> Type # | |
| Show Compression Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> Compression -> ShowS # show :: Compression -> String # showList :: [Compression] -> ShowS # | |
| Eq Compression Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| type Rep Compression Source # | |
Defined in Database.Bloodhound.Internal.Client | |
A measure of bytes used for various configurations. You may want
to use smart constructors like gigabytes for larger values.
>>>gigabytes 9Bytes 9000000000
>>>megabytes 9Bytes 9000000
>>>kilobytes 9Bytes 9000
Constructors
| FSSimple | |
| FSBuffered |
data InitialShardCount Source #
Instances
data NodeAttrFilter Source #
Constructors
| NodeAttrFilter | |
Fields | |
Instances
| Show NodeAttrFilter Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeAttrFilter -> ShowS # show :: NodeAttrFilter -> String # showList :: [NodeAttrFilter] -> ShowS # | |
| Eq NodeAttrFilter Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeAttrFilter -> NodeAttrFilter -> Bool # (/=) :: NodeAttrFilter -> NodeAttrFilter -> Bool # | |
| Ord NodeAttrFilter Source # | |
Defined in Database.Bloodhound.Internal.Client 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.Client Methods showsPrec :: Int -> NodeAttrName -> ShowS # show :: NodeAttrName -> String # showList :: [NodeAttrName] -> ShowS # | |
| Eq NodeAttrName Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Ord NodeAttrName Source # | |
Defined in Database.Bloodhound.Internal.Client 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 CompoundFormat Source #
Constructors
| CompoundFileFormat Bool | |
| MergeSegmentVsTotalIndex Double | percentage between 0 and 1 where 0 is false, 1 is true |
Instances
newtype NominalDiffTimeJSON Source #
Constructors
| NominalDiffTimeJSON | |
Fields | |
Instances
| FromJSON NominalDiffTimeJSON Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NominalDiffTimeJSON # parseJSONList :: Value -> Parser [NominalDiffTimeJSON] # | |
| ToJSON NominalDiffTimeJSON Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: NominalDiffTimeJSON -> Value # toEncoding :: NominalDiffTimeJSON -> Encoding # toJSONList :: [NominalDiffTimeJSON] -> Value # toEncodingList :: [NominalDiffTimeJSON] -> Encoding # omitField :: NominalDiffTimeJSON -> Bool # | |
data IndexSettingsSummary Source #
Constructors
| IndexSettingsSummary | |
Instances
| FromJSON IndexSettingsSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser IndexSettingsSummary # parseJSONList :: Value -> Parser [IndexSettingsSummary] # | |
| Show IndexSettingsSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexSettingsSummary -> ShowS # show :: IndexSettingsSummary -> String # showList :: [IndexSettingsSummary] -> ShowS # | |
| Eq IndexSettingsSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexSettingsSummary -> IndexSettingsSummary -> Bool # (/=) :: IndexSettingsSummary -> IndexSettingsSummary -> 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.Client Methods showsPrec :: Int -> OpenCloseIndex -> ShowS # show :: OpenCloseIndex -> String # showList :: [OpenCloseIndex] -> ShowS # | |
| Eq OpenCloseIndex Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: OpenCloseIndex -> OpenCloseIndex -> Bool # (/=) :: OpenCloseIndex -> OpenCloseIndex -> Bool # | |
Constructors
| GeoPointType | |
| GeoShapeType | |
| FloatType | |
| IntegerType | |
| LongType | |
| ShortType | |
| ByteType |
newtype FieldDefinition Source #
Constructors
| FieldDefinition | |
Instances
| Show FieldDefinition Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> FieldDefinition -> ShowS # show :: FieldDefinition -> String # showList :: [FieldDefinition] -> ShowS # | |
| Eq FieldDefinition Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: FieldDefinition -> FieldDefinition -> Bool # (/=) :: FieldDefinition -> FieldDefinition -> 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.Client Methods toJSON :: IndexTemplate -> Value # toEncoding :: IndexTemplate -> Encoding # toJSONList :: [IndexTemplate] -> Value # toEncodingList :: [IndexTemplate] -> Encoding # omitField :: IndexTemplate -> Bool # | |
data MappingField Source #
Constructors
| MappingField | |
Fields | |
Instances
| Show MappingField Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> MappingField -> ShowS # show :: MappingField -> String # showList :: [MappingField] -> ShowS # | |
| Eq MappingField Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Support for type reification of Mappings is currently incomplete, for
now the mapping API verbiage expects a ToJSONable 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 | |
data UpsertActionMetadata Source #
Constructors
| UA_RetryOnConflict Int | |
| UA_Version Int |
Instances
| Show UpsertActionMetadata Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> UpsertActionMetadata -> ShowS # show :: UpsertActionMetadata -> String # showList :: [UpsertActionMetadata] -> ShowS # | |
| Eq UpsertActionMetadata Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: UpsertActionMetadata -> UpsertActionMetadata -> Bool # (/=) :: UpsertActionMetadata -> UpsertActionMetadata -> Bool # | |
data UpsertPayload Source #
Instances
| Show UpsertPayload Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> UpsertPayload -> ShowS # show :: UpsertPayload -> String # showList :: [UpsertPayload] -> ShowS # | |
| Eq UpsertPayload Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: UpsertPayload -> UpsertPayload -> Bool # (/=) :: UpsertPayload -> UpsertPayload -> Bool # | |
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
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.Client Methods showsPrec :: Int -> BulkOperation -> ShowS # show :: BulkOperation -> String # showList :: [BulkOperation] -> ShowS # | |
| Eq BulkOperation Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: BulkOperation -> BulkOperation -> Bool # (/=) :: BulkOperation -> BulkOperation -> Bool # | |
data IndexAlias Source #
Constructors
| IndexAlias | |
Fields | |
Instances
| ToJSON IndexAlias Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: IndexAlias -> Value # toEncoding :: IndexAlias -> Encoding # toJSONList :: [IndexAlias] -> Value # toEncodingList :: [IndexAlias] -> Encoding # omitField :: IndexAlias -> Bool # | |
| Show IndexAlias Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexAlias -> ShowS # show :: IndexAlias -> String # showList :: [IndexAlias] -> ShowS # | |
| Eq IndexAlias Source # | |
Defined in Database.Bloodhound.Internal.Client | |
data IndexAliasAction Source #
Constructors
| AddAlias IndexAlias IndexAliasCreate | |
| RemoveAlias IndexAlias |
Instances
| ToJSON IndexAliasAction Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: IndexAliasAction -> Value # toEncoding :: IndexAliasAction -> Encoding # toJSONList :: [IndexAliasAction] -> Value # toEncodingList :: [IndexAliasAction] -> Encoding # omitField :: IndexAliasAction -> Bool # | |
| Show IndexAliasAction Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexAliasAction -> ShowS # show :: IndexAliasAction -> String # showList :: [IndexAliasAction] -> ShowS # | |
| Eq IndexAliasAction Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexAliasAction -> IndexAliasAction -> Bool # (/=) :: IndexAliasAction -> IndexAliasAction -> Bool # | |
data IndexAliasCreate Source #
Constructors
| IndexAliasCreate | |
Fields | |
Instances
| FromJSON IndexAliasCreate Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser IndexAliasCreate # parseJSONList :: Value -> Parser [IndexAliasCreate] # | |
| ToJSON IndexAliasCreate Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: IndexAliasCreate -> Value # toEncoding :: IndexAliasCreate -> Encoding # toJSONList :: [IndexAliasCreate] -> Value # toEncodingList :: [IndexAliasCreate] -> Encoding # omitField :: IndexAliasCreate -> Bool # | |
| Show IndexAliasCreate Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexAliasCreate -> ShowS # show :: IndexAliasCreate -> String # showList :: [IndexAliasCreate] -> ShowS # | |
| Eq IndexAliasCreate Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexAliasCreate -> IndexAliasCreate -> Bool # (/=) :: IndexAliasCreate -> IndexAliasCreate -> Bool # | |
data AliasRouting Source #
Constructors
| AllAliasRouting RoutingValue | |
| GranularAliasRouting (Maybe SearchAliasRouting) (Maybe IndexAliasRouting) |
Instances
| FromJSON AliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| ToJSON AliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: AliasRouting -> Value # toEncoding :: AliasRouting -> Encoding # toJSONList :: [AliasRouting] -> Value # toEncodingList :: [AliasRouting] -> Encoding # omitField :: AliasRouting -> Bool # | |
| Show AliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> AliasRouting -> ShowS # show :: AliasRouting -> String # showList :: [AliasRouting] -> ShowS # | |
| Eq AliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client | |
newtype SearchAliasRouting Source #
Constructors
| SearchAliasRouting (NonEmpty RoutingValue) |
Instances
newtype IndexAliasRouting Source #
Constructors
| IndexAliasRouting RoutingValue |
Instances
newtype RoutingValue Source #
Constructors
| RoutingValue | |
Fields
| |
Instances
| FromJSON RoutingValue Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| ToJSON RoutingValue Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: RoutingValue -> Value # toEncoding :: RoutingValue -> Encoding # toJSONList :: [RoutingValue] -> Value # toEncodingList :: [RoutingValue] -> Encoding # omitField :: RoutingValue -> Bool # | |
| Show RoutingValue Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> RoutingValue -> ShowS # show :: RoutingValue -> String # showList :: [RoutingValue] -> ShowS # | |
| Eq RoutingValue Source # | |
Defined in Database.Bloodhound.Internal.Client | |
newtype IndexAliasesSummary Source #
Constructors
| IndexAliasesSummary | |
Fields | |
Instances
| FromJSON IndexAliasesSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser IndexAliasesSummary # parseJSONList :: Value -> Parser [IndexAliasesSummary] # | |
| Show IndexAliasesSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexAliasesSummary -> ShowS # show :: IndexAliasesSummary -> String # showList :: [IndexAliasesSummary] -> ShowS # | |
| Eq IndexAliasesSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexAliasesSummary -> IndexAliasesSummary -> Bool # (/=) :: IndexAliasesSummary -> IndexAliasesSummary -> 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.Client Methods showsPrec :: Int -> IndexAliasSummary -> ShowS # show :: IndexAliasSummary -> String # showList :: [IndexAliasSummary] -> ShowS # | |
| Eq IndexAliasSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexAliasSummary -> IndexAliasSummary -> Bool # (/=) :: IndexAliasSummary -> IndexAliasSummary -> Bool # | |
data JoinRelation Source #
Instances
| Show JoinRelation Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JoinRelation -> ShowS # show :: JoinRelation -> String # showList :: [JoinRelation] -> ShowS # | |
| Eq JoinRelation Source # | |
Defined in Database.Bloodhound.Internal.Client | |
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.Client Methods showsPrec :: Int -> IndexDocumentSettings -> ShowS # show :: IndexDocumentSettings -> String # showList :: [IndexDocumentSettings] -> ShowS # | |
| Eq IndexDocumentSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexDocumentSettings -> IndexDocumentSettings -> Bool # (/=) :: IndexDocumentSettings -> IndexDocumentSettings -> Bool # | |
defaultIndexDocumentSettings :: IndexDocumentSettings Source #
Reasonable default settings. Chooses no version control and no parent.
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.Client Methods showsPrec :: Int -> IndexSelection -> ShowS # show :: IndexSelection -> String # showList :: [IndexSelection] -> ShowS # | |
| Eq IndexSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexSelection -> IndexSelection -> Bool # (/=) :: IndexSelection -> IndexSelection -> 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.Client Methods showsPrec :: Int -> NodeSelection -> ShowS # show :: NodeSelection -> String # showList :: [NodeSelection] -> ShowS # | |
| Eq NodeSelection Source # | |
Defined in Database.Bloodhound.Internal.Client 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.Client Methods showsPrec :: Int -> NodeSelector -> ShowS # show :: NodeSelector -> String # showList :: [NodeSelector] -> ShowS # | |
| Eq NodeSelector Source # | |
Defined in Database.Bloodhound.Internal.Client | |
newtype TemplateName Source #
TemplateName is used to describe which template to querycreatedelete
Constructors
| TemplateName Text |
Instances
newtype IndexPattern Source #
IndexPattern represents a pattern which is matched against index names
Constructors
| IndexPattern Text |
Instances
newtype EsUsername Source #
Username type used for HTTP Basic authentication. See basicAuthHook.
Constructors
| EsUsername | |
Fields
| |
Instances
| Read EsUsername Source # | |
Defined in Database.Bloodhound.Internal.Client Methods readsPrec :: Int -> ReadS EsUsername # readList :: ReadS [EsUsername] # readPrec :: ReadPrec EsUsername # readListPrec :: ReadPrec [EsUsername] # | |
| Show EsUsername Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> EsUsername -> ShowS # show :: EsUsername -> String # showList :: [EsUsername] -> ShowS # | |
| Eq EsUsername Source # | |
Defined in Database.Bloodhound.Internal.Client | |
newtype EsPassword Source #
Password type used for HTTP Basic authentication. See basicAuthHook.
Constructors
| EsPassword | |
Fields
| |
Instances
| Read EsPassword Source # | |
Defined in Database.Bloodhound.Internal.Client Methods readsPrec :: Int -> ReadS EsPassword # readList :: ReadS [EsPassword] # readPrec :: ReadPrec EsPassword # readListPrec :: ReadPrec [EsPassword] # | |
| Show EsPassword Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> EsPassword -> ShowS # show :: EsPassword -> String # showList :: [EsPassword] -> ShowS # | |
| Eq EsPassword Source # | |
Defined in Database.Bloodhound.Internal.Client | |
data SnapshotRepoSelection Source #
Constructors
| SnapshotRepoList (NonEmpty SnapshotRepoPattern) | |
| AllSnapshotRepos |
Instances
| Show SnapshotRepoSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotRepoSelection -> ShowS # show :: SnapshotRepoSelection -> String # showList :: [SnapshotRepoSelection] -> ShowS # | |
| Eq SnapshotRepoSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotRepoSelection -> SnapshotRepoSelection -> Bool # (/=) :: SnapshotRepoSelection -> SnapshotRepoSelection -> Bool # | |
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.Client Methods showsPrec :: Int -> SnapshotRepoPattern -> ShowS # show :: SnapshotRepoPattern -> String # showList :: [SnapshotRepoPattern] -> ShowS # | |
| Eq SnapshotRepoPattern Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotRepoPattern -> SnapshotRepoPattern -> Bool # (/=) :: SnapshotRepoPattern -> SnapshotRepoPattern -> Bool # | |
newtype SnapshotRepoName Source #
The unique name of a snapshot repository.
Constructors
| SnapshotRepoName | |
Fields | |
Instances
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.Client Methods showsPrec :: Int -> GenericSnapshotRepo -> ShowS # show :: GenericSnapshotRepo -> String # showList :: [GenericSnapshotRepo] -> ShowS # | |
| SnapshotRepo GenericSnapshotRepo Source # | |
| Eq GenericSnapshotRepo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: GenericSnapshotRepo -> GenericSnapshotRepo -> Bool # (/=) :: GenericSnapshotRepo -> GenericSnapshotRepo -> Bool # | |
newtype SnapshotRepoType Source #
Constructors
| SnapshotRepoType | |
Fields | |
Instances
newtype GenericSnapshotRepoSettings Source #
Opaque representation of snapshot repo settings. Instances of
SnapshotRepo will produce this.
Constructors
| GenericSnapshotRepoSettings | |
Fields | |
Instances
| FromJSON GenericSnapshotRepoSettings Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| ToJSON GenericSnapshotRepoSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: GenericSnapshotRepoSettings -> Value # toEncoding :: GenericSnapshotRepoSettings -> Encoding # toJSONList :: [GenericSnapshotRepoSettings] -> Value # toEncodingList :: [GenericSnapshotRepoSettings] -> Encoding # | |
| Show GenericSnapshotRepoSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> GenericSnapshotRepoSettings -> ShowS # show :: GenericSnapshotRepoSettings -> String # showList :: [GenericSnapshotRepoSettings] -> ShowS # | |
| Eq GenericSnapshotRepoSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: GenericSnapshotRepoSettings -> GenericSnapshotRepoSettings -> Bool # (/=) :: GenericSnapshotRepoSettings -> GenericSnapshotRepoSettings -> Bool # | |
newtype SnapshotVerification Source #
The result of running verifySnapshotRepo.
Constructors
| SnapshotVerification | |
Instances
| FromJSON SnapshotVerification Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser SnapshotVerification # parseJSONList :: Value -> Parser [SnapshotVerification] # | |
| Show SnapshotVerification Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotVerification -> ShowS # show :: SnapshotVerification -> String # showList :: [SnapshotVerification] -> ShowS # | |
| Eq SnapshotVerification Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotVerification -> SnapshotVerification -> Bool # (/=) :: SnapshotVerification -> SnapshotVerification -> Bool # | |
data SnapshotNodeVerification Source #
A node that has verified a snapshot
Constructors
| SnapshotNodeVerification | |
Fields | |
Instances
| Show SnapshotNodeVerification Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotNodeVerification -> ShowS # show :: SnapshotNodeVerification -> String # showList :: [SnapshotNodeVerification] -> ShowS # | |
| Eq SnapshotNodeVerification Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotNodeVerification -> SnapshotNodeVerification -> Bool # (/=) :: SnapshotNodeVerification -> SnapshotNodeVerification -> Bool # | |
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.Client | |
| Show FullNodeId Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> FullNodeId -> ShowS # show :: FullNodeId -> String # showList :: [FullNodeId] -> ShowS # | |
| Eq FullNodeId Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Ord FullNodeId Source # | |
Defined in Database.Bloodhound.Internal.Client 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 # | |
A human-readable node name that is supplied by the user in the node config or automatically generated by Elasticsearch.
newtype ClusterName Source #
Constructors
| ClusterName | |
Fields
| |
Instances
| FromJSON ClusterName Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show ClusterName Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> ClusterName -> ShowS # show :: ClusterName -> String # showList :: [ClusterName] -> ShowS # | |
| Eq ClusterName Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Ord ClusterName Source # | |
Defined in Database.Bloodhound.Internal.Client 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 # | |
Constructors
| NodesInfo | |
Fields
| |
data NodesStats Source #
Constructors
| NodesStats | |
Fields | |
Instances
| FromJSON NodesStats Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show NodesStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodesStats -> ShowS # show :: NodesStats -> String # showList :: [NodesStats] -> ShowS # | |
| Eq NodesStats Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Constructors
data NodeBreakersStats Source #
Constructors
| NodeBreakersStats | |
Instances
| FromJSON NodeBreakersStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeBreakersStats # parseJSONList :: Value -> Parser [NodeBreakersStats] # | |
| Show NodeBreakersStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeBreakersStats -> ShowS # show :: NodeBreakersStats -> String # showList :: [NodeBreakersStats] -> ShowS # | |
| Eq NodeBreakersStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeBreakersStats -> NodeBreakersStats -> Bool # (/=) :: NodeBreakersStats -> NodeBreakersStats -> Bool # | |
data NodeBreakerStats Source #
Constructors
| NodeBreakerStats | |
Fields | |
Instances
| FromJSON NodeBreakerStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeBreakerStats # parseJSONList :: Value -> Parser [NodeBreakerStats] # | |
| Show NodeBreakerStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeBreakerStats -> ShowS # show :: NodeBreakerStats -> String # showList :: [NodeBreakerStats] -> ShowS # | |
| Eq NodeBreakerStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeBreakerStats -> NodeBreakerStats -> Bool # (/=) :: NodeBreakerStats -> NodeBreakerStats -> Bool # | |
data NodeHTTPStats Source #
Constructors
| NodeHTTPStats | |
Fields | |
Instances
| FromJSON NodeHTTPStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeHTTPStats # parseJSONList :: Value -> Parser [NodeHTTPStats] # | |
| Show NodeHTTPStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeHTTPStats -> ShowS # show :: NodeHTTPStats -> String # showList :: [NodeHTTPStats] -> ShowS # | |
| Eq NodeHTTPStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeHTTPStats -> NodeHTTPStats -> Bool # (/=) :: NodeHTTPStats -> NodeHTTPStats -> Bool # | |
data NodeTransportStats Source #
Constructors
| NodeTransportStats | |
Fields | |
Instances
| FromJSON NodeTransportStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeTransportStats # parseJSONList :: Value -> Parser [NodeTransportStats] # | |
| Show NodeTransportStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeTransportStats -> ShowS # show :: NodeTransportStats -> String # showList :: [NodeTransportStats] -> ShowS # | |
| Eq NodeTransportStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeTransportStats -> NodeTransportStats -> Bool # (/=) :: NodeTransportStats -> NodeTransportStats -> Bool # | |
data NodeFSStats Source #
Constructors
| NodeFSStats | |
Fields | |
Instances
| FromJSON NodeFSStats Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show NodeFSStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeFSStats -> ShowS # show :: NodeFSStats -> String # showList :: [NodeFSStats] -> ShowS # | |
| Eq NodeFSStats Source # | |
Defined in Database.Bloodhound.Internal.Client | |
data NodeDataPathStats Source #
Constructors
Instances
| FromJSON NodeDataPathStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeDataPathStats # parseJSONList :: Value -> Parser [NodeDataPathStats] # | |
| Show NodeDataPathStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeDataPathStats -> ShowS # show :: NodeDataPathStats -> String # showList :: [NodeDataPathStats] -> ShowS # | |
| Eq NodeDataPathStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeDataPathStats -> NodeDataPathStats -> Bool # (/=) :: NodeDataPathStats -> NodeDataPathStats -> Bool # | |
data NodeFSTotalStats Source #
Constructors
Instances
| FromJSON NodeFSTotalStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeFSTotalStats # parseJSONList :: Value -> Parser [NodeFSTotalStats] # | |
| Show NodeFSTotalStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeFSTotalStats -> ShowS # show :: NodeFSTotalStats -> String # showList :: [NodeFSTotalStats] -> ShowS # | |
| Eq NodeFSTotalStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeFSTotalStats -> NodeFSTotalStats -> Bool # (/=) :: NodeFSTotalStats -> NodeFSTotalStats -> Bool # | |
data NodeNetworkStats Source #
Constructors
| NodeNetworkStats | |
Instances
| FromJSON NodeNetworkStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeNetworkStats # parseJSONList :: Value -> Parser [NodeNetworkStats] # | |
| Show NodeNetworkStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeNetworkStats -> ShowS # show :: NodeNetworkStats -> String # showList :: [NodeNetworkStats] -> ShowS # | |
| Eq NodeNetworkStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeNetworkStats -> NodeNetworkStats -> Bool # (/=) :: NodeNetworkStats -> NodeNetworkStats -> Bool # | |
data NodeThreadPoolStats Source #
Constructors
| NodeThreadPoolStats | |
Instances
| FromJSON NodeThreadPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeThreadPoolStats # parseJSONList :: Value -> Parser [NodeThreadPoolStats] # | |
| Show NodeThreadPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeThreadPoolStats -> ShowS # show :: NodeThreadPoolStats -> String # showList :: [NodeThreadPoolStats] -> ShowS # | |
| Eq NodeThreadPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeThreadPoolStats -> NodeThreadPoolStats -> Bool # (/=) :: NodeThreadPoolStats -> NodeThreadPoolStats -> Bool # | |
data NodeJVMStats Source #
Constructors
Instances
| FromJSON NodeJVMStats Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show NodeJVMStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeJVMStats -> ShowS # show :: NodeJVMStats -> String # showList :: [NodeJVMStats] -> ShowS # | |
| Eq NodeJVMStats Source # | |
Defined in Database.Bloodhound.Internal.Client | |
data JVMBufferPoolStats Source #
Constructors
| JVMBufferPoolStats | |
Instances
| FromJSON JVMBufferPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser JVMBufferPoolStats # parseJSONList :: Value -> Parser [JVMBufferPoolStats] # | |
| Show JVMBufferPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JVMBufferPoolStats -> ShowS # show :: JVMBufferPoolStats -> String # showList :: [JVMBufferPoolStats] -> ShowS # | |
| Eq JVMBufferPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: JVMBufferPoolStats -> JVMBufferPoolStats -> Bool # (/=) :: JVMBufferPoolStats -> JVMBufferPoolStats -> Bool # | |
data JVMGCStats Source #
Constructors
| JVMGCStats | |
Instances
| FromJSON JVMGCStats Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show JVMGCStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JVMGCStats -> ShowS # show :: JVMGCStats -> String # showList :: [JVMGCStats] -> ShowS # | |
| Eq JVMGCStats Source # | |
Defined in Database.Bloodhound.Internal.Client | |
data JVMPoolStats Source #
Constructors
| JVMPoolStats | |
Fields | |
Instances
| FromJSON JVMPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show JVMPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JVMPoolStats -> ShowS # show :: JVMPoolStats -> String # showList :: [JVMPoolStats] -> ShowS # | |
| Eq JVMPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client | |
data NodeProcessStats Source #
Constructors
| NodeProcessStats | |
Instances
| FromJSON NodeProcessStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeProcessStats # parseJSONList :: Value -> Parser [NodeProcessStats] # | |
| Show NodeProcessStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeProcessStats -> ShowS # show :: NodeProcessStats -> String # showList :: [NodeProcessStats] -> ShowS # | |
| Eq NodeProcessStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeProcessStats -> NodeProcessStats -> Bool # (/=) :: NodeProcessStats -> NodeProcessStats -> Bool # | |
data NodeOSStats Source #
Constructors
| NodeOSStats | |
Fields | |
Instances
| FromJSON NodeOSStats Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show NodeOSStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeOSStats -> ShowS # show :: NodeOSStats -> String # showList :: [NodeOSStats] -> ShowS # | |
| Eq NodeOSStats Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Constructors
| LoadAvgs | |
Fields
| |
data NodeIndicesStats Source #
Constructors
Instances
| FromJSON NodeIndicesStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeIndicesStats # parseJSONList :: Value -> Parser [NodeIndicesStats] # | |
| Show NodeIndicesStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeIndicesStats -> ShowS # show :: NodeIndicesStats -> String # showList :: [NodeIndicesStats] -> ShowS # | |
| Eq NodeIndicesStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeIndicesStats -> NodeIndicesStats -> Bool # (/=) :: NodeIndicesStats -> NodeIndicesStats -> Bool # | |
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 # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show EsAddress Source # | |
| Eq EsAddress Source # | |
| Ord EsAddress Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Typically a 7 character hex string.
Instances
| FromJSON BuildHash Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| ToJSON BuildHash Source # | |
| Generic BuildHash Source # | |
| Show BuildHash Source # | |
| Eq BuildHash Source # | |
| Ord BuildHash Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| type Rep BuildHash Source # | |
Defined in Database.Bloodhound.Internal.Client | |
newtype PluginName Source #
Constructors
| PluginName | |
Fields
| |
Instances
| FromJSON PluginName Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show PluginName Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> PluginName -> ShowS # show :: PluginName -> String # showList :: [PluginName] -> ShowS # | |
| Eq PluginName Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Ord PluginName Source # | |
Defined in Database.Bloodhound.Internal.Client 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 # | |
Constructors
| NodeInfo | |
Fields
| |
data NodePluginInfo Source #
Constructors
| NodePluginInfo | |
Fields
| |
Instances
| FromJSON NodePluginInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodePluginInfo # parseJSONList :: Value -> Parser [NodePluginInfo] # | |
| Show NodePluginInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodePluginInfo -> ShowS # show :: NodePluginInfo -> String # showList :: [NodePluginInfo] -> ShowS # | |
| Eq NodePluginInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodePluginInfo -> NodePluginInfo -> Bool # (/=) :: NodePluginInfo -> NodePluginInfo -> Bool # | |
data NodeHTTPInfo Source #
Constructors
| NodeHTTPInfo | |
Instances
| FromJSON NodeHTTPInfo Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show NodeHTTPInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeHTTPInfo -> ShowS # show :: NodeHTTPInfo -> String # showList :: [NodeHTTPInfo] -> ShowS # | |
| Eq NodeHTTPInfo Source # | |
Defined in Database.Bloodhound.Internal.Client | |
data NodeTransportInfo Source #
Constructors
| NodeTransportInfo | |
Instances
| FromJSON NodeTransportInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeTransportInfo # parseJSONList :: Value -> Parser [NodeTransportInfo] # | |
| Show NodeTransportInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeTransportInfo -> ShowS # show :: NodeTransportInfo -> String # showList :: [NodeTransportInfo] -> ShowS # | |
| Eq NodeTransportInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeTransportInfo -> NodeTransportInfo -> Bool # (/=) :: NodeTransportInfo -> NodeTransportInfo -> Bool # | |
data BoundTransportAddress Source #
Constructors
| BoundTransportAddress | |
Fields
| |
Instances
| FromJSON BoundTransportAddress Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser BoundTransportAddress # parseJSONList :: Value -> Parser [BoundTransportAddress] # | |
| Show BoundTransportAddress Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> BoundTransportAddress -> ShowS # show :: BoundTransportAddress -> String # showList :: [BoundTransportAddress] -> ShowS # | |
| Eq BoundTransportAddress Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: BoundTransportAddress -> BoundTransportAddress -> Bool # (/=) :: BoundTransportAddress -> BoundTransportAddress -> Bool # | |
data NodeNetworkInfo Source #
Constructors
| NodeNetworkInfo | |
Instances
| FromJSON NodeNetworkInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeNetworkInfo # parseJSONList :: Value -> Parser [NodeNetworkInfo] # | |
| Show NodeNetworkInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeNetworkInfo -> ShowS # show :: NodeNetworkInfo -> String # showList :: [NodeNetworkInfo] -> ShowS # | |
| Eq NodeNetworkInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeNetworkInfo -> NodeNetworkInfo -> Bool # (/=) :: NodeNetworkInfo -> NodeNetworkInfo -> Bool # | |
newtype MacAddress Source #
Constructors
| MacAddress | |
Fields
| |
Instances
| FromJSON MacAddress Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show MacAddress Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> MacAddress -> ShowS # show :: MacAddress -> String # showList :: [MacAddress] -> ShowS # | |
| Eq MacAddress Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Ord MacAddress Source # | |
Defined in Database.Bloodhound.Internal.Client 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
data NodeNetworkInterface Source #
Constructors
| NodeNetworkInterface | |
Instances
| FromJSON NodeNetworkInterface Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeNetworkInterface # parseJSONList :: Value -> Parser [NodeNetworkInterface] # | |
| Show NodeNetworkInterface Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeNetworkInterface -> ShowS # show :: NodeNetworkInterface -> String # showList :: [NodeNetworkInterface] -> ShowS # | |
| Eq NodeNetworkInterface Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeNetworkInterface -> NodeNetworkInterface -> Bool # (/=) :: NodeNetworkInterface -> NodeNetworkInterface -> Bool # | |
data ThreadPool Source #
Constructors
| ThreadPool | |
Fields | |
Instances
| Show ThreadPool Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> ThreadPool -> ShowS # show :: ThreadPool -> String # showList :: [ThreadPool] -> ShowS # | |
| Eq ThreadPool Source # | |
Defined in Database.Bloodhound.Internal.Client | |
data NodeThreadPoolInfo Source #
Constructors
| NodeThreadPoolInfo | |
Instances
| FromJSON NodeThreadPoolInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeThreadPoolInfo # parseJSONList :: Value -> Parser [NodeThreadPoolInfo] # | |
| Show NodeThreadPoolInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeThreadPoolInfo -> ShowS # show :: NodeThreadPoolInfo -> String # showList :: [NodeThreadPoolInfo] -> ShowS # | |
| Eq NodeThreadPoolInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeThreadPoolInfo -> NodeThreadPoolInfo -> Bool # (/=) :: NodeThreadPoolInfo -> NodeThreadPoolInfo -> Bool # | |
data ThreadPoolSize Source #
Constructors
| ThreadPoolBounded Int | |
| ThreadPoolUnbounded |
Instances
| FromJSON ThreadPoolSize Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser ThreadPoolSize # parseJSONList :: Value -> Parser [ThreadPoolSize] # | |
| Show ThreadPoolSize Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> ThreadPoolSize -> ShowS # show :: ThreadPoolSize -> String # showList :: [ThreadPoolSize] -> ShowS # | |
| Eq ThreadPoolSize Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: ThreadPoolSize -> ThreadPoolSize -> Bool # (/=) :: ThreadPoolSize -> ThreadPoolSize -> Bool # | |
data ThreadPoolType Source #
Instances
| FromJSON ThreadPoolType Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser ThreadPoolType # parseJSONList :: Value -> Parser [ThreadPoolType] # | |
| Show ThreadPoolType Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> ThreadPoolType -> ShowS # show :: ThreadPoolType -> String # showList :: [ThreadPoolType] -> ShowS # | |
| Eq ThreadPoolType Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: ThreadPoolType -> ThreadPoolType -> Bool # (/=) :: ThreadPoolType -> ThreadPoolType -> Bool # | |
data NodeJVMInfo Source #
Constructors
| NodeJVMInfo | |
Fields
| |
Instances
| FromJSON NodeJVMInfo Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show NodeJVMInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeJVMInfo -> ShowS # show :: NodeJVMInfo -> String # showList :: [NodeJVMInfo] -> ShowS # | |
| Eq NodeJVMInfo Source # | |
Defined in Database.Bloodhound.Internal.Client | |
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.Client | |
| Show JVMVersion Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JVMVersion -> ShowS # show :: JVMVersion -> String # showList :: [JVMVersion] -> ShowS # | |
| Eq JVMVersion Source # | |
Defined in Database.Bloodhound.Internal.Client | |
data JVMMemoryInfo Source #
Constructors
| JVMMemoryInfo | |
Instances
| FromJSON JVMMemoryInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser JVMMemoryInfo # parseJSONList :: Value -> Parser [JVMMemoryInfo] # | |
| Show JVMMemoryInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JVMMemoryInfo -> ShowS # show :: JVMMemoryInfo -> String # showList :: [JVMMemoryInfo] -> ShowS # | |
| Eq JVMMemoryInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: JVMMemoryInfo -> JVMMemoryInfo -> Bool # (/=) :: JVMMemoryInfo -> JVMMemoryInfo -> Bool # | |
Constructors
| VMVersion | |
Fields
| |
newtype JVMMemoryPool Source #
Constructors
| JVMMemoryPool | |
Fields | |
Instances
| FromJSON JVMMemoryPool Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser JVMMemoryPool # parseJSONList :: Value -> Parser [JVMMemoryPool] # | |
| Show JVMMemoryPool Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JVMMemoryPool -> ShowS # show :: JVMMemoryPool -> String # showList :: [JVMMemoryPool] -> ShowS # | |
| Eq JVMMemoryPool Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: JVMMemoryPool -> JVMMemoryPool -> Bool # (/=) :: JVMMemoryPool -> JVMMemoryPool -> Bool # | |
newtype JVMGCCollector Source #
Constructors
| JVMGCCollector | |
Fields | |
Instances
| FromJSON JVMGCCollector Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser JVMGCCollector # parseJSONList :: Value -> Parser [JVMGCCollector] # | |
| Show JVMGCCollector Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JVMGCCollector -> ShowS # show :: JVMGCCollector -> String # showList :: [JVMGCCollector] -> ShowS # | |
| Eq JVMGCCollector Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: JVMGCCollector -> JVMGCCollector -> Bool # (/=) :: JVMGCCollector -> JVMGCCollector -> Bool # | |
data NodeOSInfo Source #
Constructors
| NodeOSInfo | |
Fields | |
Instances
| FromJSON NodeOSInfo Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show NodeOSInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeOSInfo -> ShowS # show :: NodeOSInfo -> String # showList :: [NodeOSInfo] -> ShowS # | |
| Eq NodeOSInfo Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Constructors
| CPUInfo | |
Fields
| |
data NodeProcessInfo Source #
Constructors
| NodeProcessInfo | |
Instances
| FromJSON NodeProcessInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeProcessInfo # parseJSONList :: Value -> Parser [NodeProcessInfo] # | |
| Show NodeProcessInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeProcessInfo -> ShowS # show :: NodeProcessInfo -> String # showList :: [NodeProcessInfo] -> ShowS # | |
| Eq NodeProcessInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeProcessInfo -> NodeProcessInfo -> Bool # (/=) :: NodeProcessInfo -> NodeProcessInfo -> Bool # | |
data ShardResult Source #
Constructors
| ShardResult | |
Fields
| |
Instances
| FromJSON ShardResult Source # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show ShardResult Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> ShardResult -> ShowS # show :: ShardResult -> String # showList :: [ShardResult] -> ShowS # | |
| Eq ShardResult Source # | |
Defined in Database.Bloodhound.Internal.Client | |
data SnapshotState Source #
Constructors
| SnapshotInit | |
| SnapshotStarted | |
| SnapshotSuccess | |
| SnapshotFailed | |
| SnapshotAborted | |
| SnapshotMissing | |
| SnapshotWaiting |
Instances
| FromJSON SnapshotState Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser SnapshotState # parseJSONList :: Value -> Parser [SnapshotState] # | |
| Show SnapshotState Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotState -> ShowS # show :: SnapshotState -> String # showList :: [SnapshotState] -> ShowS # | |
| Eq SnapshotState Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotState -> SnapshotState -> Bool # (/=) :: SnapshotState -> SnapshotState -> Bool # | |
data SnapshotRestoreSettings Source #
Constructors
| SnapshotRestoreSettings | |
Fields
| |
Instances
| Show SnapshotRestoreSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotRestoreSettings -> ShowS # show :: SnapshotRestoreSettings -> String # showList :: [SnapshotRestoreSettings] -> ShowS # | |
| Eq SnapshotRestoreSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotRestoreSettings -> SnapshotRestoreSettings -> Bool # (/=) :: SnapshotRestoreSettings -> SnapshotRestoreSettings -> Bool # | |
newtype SnapshotRepoUpdateSettings Source #
Constructors
| SnapshotRepoUpdateSettings | |
Fields
| |
Instances
| Show SnapshotRepoUpdateSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotRepoUpdateSettings -> ShowS # show :: SnapshotRepoUpdateSettings -> String # showList :: [SnapshotRepoUpdateSettings] -> ShowS # | |
| Eq SnapshotRepoUpdateSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotRepoUpdateSettings -> SnapshotRepoUpdateSettings -> Bool # (/=) :: SnapshotRepoUpdateSettings -> SnapshotRepoUpdateSettings -> Bool # | |
defaultSnapshotRepoUpdateSettings :: SnapshotRepoUpdateSettings Source #
Reasonable defaults for repo creation/update
- repoUpdateVerify True
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
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.Client Methods showsPrec :: Int -> SnapshotRepoConversionError -> ShowS # show :: SnapshotRepoConversionError -> String # showList :: [SnapshotRepoConversionError] -> ShowS # | |
| Eq SnapshotRepoConversionError Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotRepoConversionError -> SnapshotRepoConversionError -> Bool # (/=) :: SnapshotRepoConversionError -> SnapshotRepoConversionError -> Bool # | |
data SnapshotCreateSettings Source #
Constructors
| SnapshotCreateSettings | |
Fields
| |
Instances
| Show SnapshotCreateSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotCreateSettings -> ShowS # show :: SnapshotCreateSettings -> String # showList :: [SnapshotCreateSettings] -> ShowS # | |
| Eq SnapshotCreateSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotCreateSettings -> SnapshotCreateSettings -> Bool # (/=) :: SnapshotCreateSettings -> SnapshotCreateSettings -> Bool # | |
defaultSnapshotCreateSettings :: SnapshotCreateSettings Source #
Reasonable defaults for snapshot creation
- snapWaitForCompletion False
- snapIndices Nothing
- snapIgnoreUnavailable False
- snapIncludeGlobalState True
- snapPartial False
data SnapshotSelection Source #
Constructors
| SnapshotList (NonEmpty SnapshotPattern) | |
| AllSnapshots |
Instances
| Show SnapshotSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotSelection -> ShowS # show :: SnapshotSelection -> String # showList :: [SnapshotSelection] -> ShowS # | |
| Eq SnapshotSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotSelection -> SnapshotSelection -> Bool # (/=) :: SnapshotSelection -> SnapshotSelection -> 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.Client Methods showsPrec :: Int -> SnapshotPattern -> ShowS # show :: SnapshotPattern -> String # showList :: [SnapshotPattern] -> ShowS # | |
| Eq SnapshotPattern Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotPattern -> SnapshotPattern -> Bool # (/=) :: SnapshotPattern -> SnapshotPattern -> 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.Client | |
| Show SnapshotInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotInfo -> ShowS # show :: SnapshotInfo -> String # showList :: [SnapshotInfo] -> ShowS # | |
| Eq SnapshotInfo Source # | |
Defined in Database.Bloodhound.Internal.Client | |
data SnapshotShardFailure Source #
Constructors
| SnapshotShardFailure | |
Instances
| FromJSON SnapshotShardFailure Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser SnapshotShardFailure # parseJSONList :: Value -> Parser [SnapshotShardFailure] # | |
| Show SnapshotShardFailure Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotShardFailure -> ShowS # show :: SnapshotShardFailure -> String # showList :: [SnapshotShardFailure] -> ShowS # | |
| Eq SnapshotShardFailure Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotShardFailure -> SnapshotShardFailure -> Bool # (/=) :: SnapshotShardFailure -> SnapshotShardFailure -> Bool # | |
newtype RestoreRenamePattern Source #
Regex-stype pattern, e.g. "index_(.+)" to match index names
Constructors
| RestoreRenamePattern | |
Instances
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.Client Methods showsPrec :: Int -> RestoreRenameToken -> ShowS # show :: RestoreRenameToken -> String # showList :: [RestoreRenameToken] -> ShowS # | |
| Eq RestoreRenameToken Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: RestoreRenameToken -> RestoreRenameToken -> Bool # (/=) :: RestoreRenameToken -> RestoreRenameToken -> Bool # | |
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 # | |
Defined in Database.Bloodhound.Internal.Client | |
| Show RRGroupRefNum Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> RRGroupRefNum -> ShowS # show :: RRGroupRefNum -> String # showList :: [RRGroupRefNum] -> ShowS # | |
| Eq RRGroupRefNum Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: RRGroupRefNum -> RRGroupRefNum -> Bool # (/=) :: RRGroupRefNum -> RRGroupRefNum -> Bool # | |
| Ord RRGroupRefNum Source # | |
Defined in Database.Bloodhound.Internal.Client 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 # | |
mkRRGroupRefNum :: Int -> Maybe RRGroupRefNum Source #
Only allows valid group number references (1-9).
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
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.Client Methods toJSON :: RestoreIndexSettings -> Value # toEncoding :: RestoreIndexSettings -> Encoding # toJSONList :: [RestoreIndexSettings] -> Value # toEncodingList :: [RestoreIndexSettings] -> Encoding # omitField :: RestoreIndexSettings -> Bool # | |
| Show RestoreIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> RestoreIndexSettings -> ShowS # show :: RestoreIndexSettings -> String # showList :: [RestoreIndexSettings] -> ShowS # | |
| Eq RestoreIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: RestoreIndexSettings -> RestoreIndexSettings -> Bool # (/=) :: RestoreIndexSettings -> RestoreIndexSettings -> Bool # | |
parseNodeStats :: FullNodeId -> Object -> Parser NodeStats Source #
parseNodeInfo :: FullNodeId -> Object -> Parser NodeInfo Source #
data TimeInterval Source #
Instances
| Read TimeInterval Source # | |
Defined in Database.Bloodhound.Internal.Client Methods readsPrec :: Int -> ReadS TimeInterval # readList :: ReadS [TimeInterval] # | |
| Show TimeInterval Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> TimeInterval -> ShowS # show :: TimeInterval -> String # showList :: [TimeInterval] -> ShowS # | |
| Eq TimeInterval Source # | |
Defined in Database.Bloodhound.Internal.Client | |
parseStringInterval :: (Monad m, MonadFail m) => String -> m NominalDiffTime Source #