Safe Haskell | None |
---|---|
Language | Haskell2010 |
Database.Bloodhound.Internal.Client
Synopsis
- data BHEnv = BHEnv {}
- newtype Server = Server Text
- 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]
- type Reply = Response LByteString
- 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 EsResult a = EsResult {
- _index :: Text
- _type :: Text
- _id :: Text
- foundResult :: Maybe (EsResultFound a)
- data EsResultFound a = EsResultFound {
- _version :: DocVersion
- _source :: a
- data EsError = EsError {
- errorStatus :: Int
- errorMessage :: Text
- data EsProtocolException = EsProtocolException {
- esProtoExMessage :: !Text
- esProtoExBody :: !LByteString
- 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 {}
- newtype DocVersion = DocVersion {}
- mkDocVersion :: Int -> Maybe DocVersion
- newtype ExternalDocVersion = ExternalDocVersion DocVersion
- data VersionControl
- 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 | |
Server
is used with the client functions to point at the ES instance
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 |
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.
Constructors
Status | |
Fields
|
data IndexSettings Source #
IndexSettings
is used to configure the shards and replicas when
you create an Elasticsearch Index.
http://www.elasticsearch.org/guide/en/elasticsearch/reference/current/indices-create-index.html
Constructors
IndexSettings | |
Instances
Eq IndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexSettings -> IndexSettings -> Bool # (/=) :: IndexSettings -> IndexSettings -> Bool # | |
Show IndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexSettings -> ShowS # show :: IndexSettings -> String # showList :: [IndexSettings] -> ShowS # | |
ToJSON IndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: IndexSettings -> Value # toEncoding :: IndexSettings -> Encoding # toJSONList :: [IndexSettings] -> Value # toEncodingList :: [IndexSettings] -> Encoding # | |
FromJSON IndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser IndexSettings # parseJSONList :: Value -> Parser [IndexSettings] # |
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
Eq IndexMappingsLimits Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexMappingsLimits -> IndexMappingsLimits -> Bool # (/=) :: IndexMappingsLimits -> IndexMappingsLimits -> Bool # | |
Show IndexMappingsLimits Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexMappingsLimits -> ShowS # show :: IndexMappingsLimits -> String # showList :: [IndexMappingsLimits] -> ShowS # | |
ToJSON IndexMappingsLimits Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: IndexMappingsLimits -> Value # toEncoding :: IndexMappingsLimits -> Encoding # toJSONList :: [IndexMappingsLimits] -> Value # toEncodingList :: [IndexMappingsLimits] -> Encoding # | |
FromJSON IndexMappingsLimits Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser IndexMappingsLimits # parseJSONList :: Value -> Parser [IndexMappingsLimits] # |
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
Eq ForceMergeIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: ForceMergeIndexSettings -> ForceMergeIndexSettings -> Bool # (/=) :: ForceMergeIndexSettings -> ForceMergeIndexSettings -> Bool # | |
Show ForceMergeIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> ForceMergeIndexSettings -> ShowS # show :: ForceMergeIndexSettings -> String # showList :: [ForceMergeIndexSettings] -> ShowS # |
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
Eq UpdatableIndexSetting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: UpdatableIndexSetting -> UpdatableIndexSetting -> Bool # (/=) :: UpdatableIndexSetting -> UpdatableIndexSetting -> Bool # | |
Show UpdatableIndexSetting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> UpdatableIndexSetting -> ShowS # show :: UpdatableIndexSetting -> String # showList :: [UpdatableIndexSetting] -> ShowS # | |
ToJSON UpdatableIndexSetting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: UpdatableIndexSetting -> Value # toEncoding :: UpdatableIndexSetting -> Encoding # toJSONList :: [UpdatableIndexSetting] -> Value # toEncodingList :: [UpdatableIndexSetting] -> Encoding # | |
FromJSON UpdatableIndexSetting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser UpdatableIndexSetting # parseJSONList :: Value -> Parser [UpdatableIndexSetting] # |
parseAttrFilter :: Value -> Parser (NonEmpty NodeAttrFilter) Source #
data ReplicaBounds Source #
Constructors
ReplicasBounded Int Int | |
ReplicasLowerBounded Int | |
ReplicasUnbounded |
Instances
Eq ReplicaBounds Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: ReplicaBounds -> ReplicaBounds -> Bool # (/=) :: ReplicaBounds -> ReplicaBounds -> Bool # | |
Show ReplicaBounds Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> ReplicaBounds -> ShowS # show :: ReplicaBounds -> String # showList :: [ReplicaBounds] -> ShowS # | |
ToJSON ReplicaBounds Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: ReplicaBounds -> Value # toEncoding :: ReplicaBounds -> Encoding # toJSONList :: [ReplicaBounds] -> Value # toEncodingList :: [ReplicaBounds] -> Encoding # | |
FromJSON ReplicaBounds Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser ReplicaBounds # parseJSONList :: Value -> Parser [ReplicaBounds] # |
data Compression Source #
Constructors
CompressionDefault | Compress with LZ4 |
CompressionBest | Compress with DEFLATE. Elastic blogs that this can reduce disk use by 15%-25%. |
Instances
Eq Compression Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Show Compression Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> Compression -> ShowS # show :: Compression -> String # showList :: [Compression] -> ShowS # | |
ToJSON Compression Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: Compression -> Value # toEncoding :: Compression -> Encoding # toJSONList :: [Compression] -> Value # toEncodingList :: [Compression] -> Encoding # | |
FromJSON 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 9
Bytes 9000000000
>>>
megabytes 9
Bytes 9000000
>>>
kilobytes 9
Bytes 9000
Constructors
FSSimple | |
FSBuffered |
data InitialShardCount Source #
Instances
Eq InitialShardCount Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: InitialShardCount -> InitialShardCount -> Bool # (/=) :: InitialShardCount -> InitialShardCount -> Bool # | |
Show InitialShardCount Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> InitialShardCount -> ShowS # show :: InitialShardCount -> String # showList :: [InitialShardCount] -> ShowS # | |
ToJSON InitialShardCount Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: InitialShardCount -> Value # toEncoding :: InitialShardCount -> Encoding # toJSONList :: [InitialShardCount] -> Value # toEncodingList :: [InitialShardCount] -> Encoding # | |
FromJSON InitialShardCount Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser InitialShardCount # parseJSONList :: Value -> Parser [InitialShardCount] # |
data NodeAttrFilter Source #
Constructors
NodeAttrFilter | |
Fields |
Instances
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 # | |
Show NodeAttrFilter Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeAttrFilter -> ShowS # show :: NodeAttrFilter -> String # showList :: [NodeAttrFilter] -> ShowS # |
newtype NodeAttrName Source #
Constructors
NodeAttrName Text |
Instances
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 # | |
Show NodeAttrName Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeAttrName -> ShowS # show :: NodeAttrName -> String # showList :: [NodeAttrName] -> ShowS # |
data CompoundFormat Source #
Constructors
CompoundFileFormat Bool | |
MergeSegmentVsTotalIndex Double | percentage between 0 and 1 where 0 is false, 1 is true |
Instances
Eq CompoundFormat Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: CompoundFormat -> CompoundFormat -> Bool # (/=) :: CompoundFormat -> CompoundFormat -> Bool # | |
Show CompoundFormat Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> CompoundFormat -> ShowS # show :: CompoundFormat -> String # showList :: [CompoundFormat] -> ShowS # | |
ToJSON CompoundFormat Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: CompoundFormat -> Value # toEncoding :: CompoundFormat -> Encoding # toJSONList :: [CompoundFormat] -> Value # toEncodingList :: [CompoundFormat] -> Encoding # | |
FromJSON CompoundFormat Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser CompoundFormat # parseJSONList :: Value -> Parser [CompoundFormat] # |
newtype NominalDiffTimeJSON Source #
Constructors
NominalDiffTimeJSON | |
Fields |
Instances
ToJSON NominalDiffTimeJSON Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: NominalDiffTimeJSON -> Value # toEncoding :: NominalDiffTimeJSON -> Encoding # toJSONList :: [NominalDiffTimeJSON] -> Value # toEncodingList :: [NominalDiffTimeJSON] -> Encoding # | |
FromJSON NominalDiffTimeJSON Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NominalDiffTimeJSON # parseJSONList :: Value -> Parser [NominalDiffTimeJSON] # |
data IndexSettingsSummary Source #
Constructors
IndexSettingsSummary | |
Instances
Eq IndexSettingsSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexSettingsSummary -> IndexSettingsSummary -> Bool # (/=) :: IndexSettingsSummary -> IndexSettingsSummary -> Bool # | |
Show IndexSettingsSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexSettingsSummary -> ShowS # show :: IndexSettingsSummary -> String # showList :: [IndexSettingsSummary] -> ShowS # | |
FromJSON IndexSettingsSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser IndexSettingsSummary # parseJSONList :: Value -> Parser [IndexSettingsSummary] # |
data OpenCloseIndex Source #
OpenCloseIndex
is a sum type for opening and closing indices.
http://www.elasticsearch.org/guide/en/elasticsearch/reference/current/indices-open-close.html
Constructors
OpenIndex | |
CloseIndex |
Instances
Eq OpenCloseIndex Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: OpenCloseIndex -> OpenCloseIndex -> Bool # (/=) :: OpenCloseIndex -> OpenCloseIndex -> Bool # | |
Show OpenCloseIndex Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> OpenCloseIndex -> ShowS # show :: OpenCloseIndex -> String # showList :: [OpenCloseIndex] -> ShowS # |
Constructors
GeoPointType | |
GeoShapeType | |
FloatType | |
IntegerType | |
LongType | |
ShortType | |
ByteType |
newtype FieldDefinition Source #
Constructors
FieldDefinition | |
Instances
Eq FieldDefinition Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: FieldDefinition -> FieldDefinition -> Bool # (/=) :: FieldDefinition -> FieldDefinition -> Bool # | |
Show FieldDefinition Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> FieldDefinition -> ShowS # show :: FieldDefinition -> String # showList :: [FieldDefinition] -> ShowS # |
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 # |
data MappingField Source #
Constructors
MappingField | |
Fields |
Instances
Eq MappingField Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Show MappingField Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> MappingField -> ShowS # show :: MappingField -> String # showList :: [MappingField] -> ShowS # |
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 |
data UpsertActionMetadata Source #
Constructors
UA_RetryOnConflict Int | |
UA_Version Int |
Instances
Eq UpsertActionMetadata Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: UpsertActionMetadata -> UpsertActionMetadata -> Bool # (/=) :: UpsertActionMetadata -> UpsertActionMetadata -> Bool # | |
Show UpsertActionMetadata Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> UpsertActionMetadata -> ShowS # show :: UpsertActionMetadata -> String # showList :: [UpsertActionMetadata] -> ShowS # |
data UpsertPayload Source #
Instances
Eq UpsertPayload Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: UpsertPayload -> UpsertPayload -> Bool # (/=) :: UpsertPayload -> UpsertPayload -> Bool # | |
Show UpsertPayload Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> UpsertPayload -> ShowS # show :: UpsertPayload -> String # showList :: [UpsertPayload] -> ShowS # |
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
Eq AllocationPolicy Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: AllocationPolicy -> AllocationPolicy -> Bool # (/=) :: AllocationPolicy -> AllocationPolicy -> Bool # | |
Show AllocationPolicy Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> AllocationPolicy -> ShowS # show :: AllocationPolicy -> String # showList :: [AllocationPolicy] -> ShowS # | |
ToJSON AllocationPolicy Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: AllocationPolicy -> Value # toEncoding :: AllocationPolicy -> Encoding # toJSONList :: [AllocationPolicy] -> Value # toEncodingList :: [AllocationPolicy] -> Encoding # | |
FromJSON AllocationPolicy Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser AllocationPolicy # parseJSONList :: Value -> Parser [AllocationPolicy] # |
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
Eq BulkOperation Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: BulkOperation -> BulkOperation -> Bool # (/=) :: BulkOperation -> BulkOperation -> Bool # | |
Show BulkOperation Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> BulkOperation -> ShowS # show :: BulkOperation -> String # showList :: [BulkOperation] -> ShowS # |
EsResult
describes the standard wrapper JSON document that you see in
successful Elasticsearch lookups or lookups that couldn't find the document.
Constructors
EsResult | |
Fields
|
data EsResultFound a Source #
EsResultFound
contains the document and its metadata inside of an
EsResult
when the document was successfully found.
Constructors
EsResultFound | |
Fields
|
Instances
Eq a => Eq (EsResultFound a) Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: EsResultFound a -> EsResultFound a -> Bool # (/=) :: EsResultFound a -> EsResultFound a -> Bool # | |
Show a => Show (EsResultFound a) Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> EsResultFound a -> ShowS # show :: EsResultFound a -> String # showList :: [EsResultFound a] -> ShowS # | |
FromJSON a => FromJSON (EsResultFound a) Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser (EsResultFound a) # parseJSONList :: Value -> Parser [EsResultFound a] # |
EsError
is the generic type that will be returned when there was a
problem. If you can't parse the expected response, its a good idea to
try parsing this.
Constructors
EsError | |
Fields
|
data EsProtocolException Source #
EsProtocolException
will be thrown if Bloodhound cannot parse a response
returned by the Elasticsearch server. If you encounter this error, please
verify that your domain data types and FromJSON instances are working properly
(for example, the a
of '[Hit a]' in 'SearchResult.searchHits.hits'). If you're
sure that your mappings are correct, then this error may be an indication of an
incompatibility between Bloodhound and Elasticsearch. Please open a bug report
and be sure to include the exception body.
Constructors
EsProtocolException | |
Fields
|
Instances
Eq EsProtocolException Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: EsProtocolException -> EsProtocolException -> Bool # (/=) :: EsProtocolException -> EsProtocolException -> Bool # | |
Show EsProtocolException Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> EsProtocolException -> ShowS # show :: EsProtocolException -> String # showList :: [EsProtocolException] -> ShowS # | |
Exception EsProtocolException Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toException :: EsProtocolException -> SomeException # fromException :: SomeException -> Maybe EsProtocolException # |
data IndexAlias Source #
Constructors
IndexAlias | |
Fields |
Instances
Eq IndexAlias Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Show IndexAlias Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexAlias -> ShowS # show :: IndexAlias -> String # showList :: [IndexAlias] -> ShowS # | |
ToJSON IndexAlias Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: IndexAlias -> Value # toEncoding :: IndexAlias -> Encoding # toJSONList :: [IndexAlias] -> Value # toEncodingList :: [IndexAlias] -> Encoding # |
data IndexAliasAction Source #
Constructors
AddAlias IndexAlias IndexAliasCreate | |
RemoveAlias IndexAlias |
Instances
Eq IndexAliasAction Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexAliasAction -> IndexAliasAction -> Bool # (/=) :: IndexAliasAction -> IndexAliasAction -> Bool # | |
Show IndexAliasAction Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexAliasAction -> ShowS # show :: IndexAliasAction -> String # showList :: [IndexAliasAction] -> ShowS # | |
ToJSON IndexAliasAction Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: IndexAliasAction -> Value # toEncoding :: IndexAliasAction -> Encoding # toJSONList :: [IndexAliasAction] -> Value # toEncodingList :: [IndexAliasAction] -> Encoding # |
data IndexAliasCreate Source #
Constructors
IndexAliasCreate | |
Fields |
Instances
Eq IndexAliasCreate Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexAliasCreate -> IndexAliasCreate -> Bool # (/=) :: IndexAliasCreate -> IndexAliasCreate -> Bool # | |
Show IndexAliasCreate Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexAliasCreate -> ShowS # show :: IndexAliasCreate -> String # showList :: [IndexAliasCreate] -> ShowS # | |
ToJSON IndexAliasCreate Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: IndexAliasCreate -> Value # toEncoding :: IndexAliasCreate -> Encoding # toJSONList :: [IndexAliasCreate] -> Value # toEncodingList :: [IndexAliasCreate] -> Encoding # | |
FromJSON IndexAliasCreate Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser IndexAliasCreate # parseJSONList :: Value -> Parser [IndexAliasCreate] # |
data AliasRouting Source #
Constructors
AllAliasRouting RoutingValue | |
GranularAliasRouting (Maybe SearchAliasRouting) (Maybe IndexAliasRouting) |
Instances
Eq AliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Show AliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> AliasRouting -> ShowS # show :: AliasRouting -> String # showList :: [AliasRouting] -> ShowS # | |
ToJSON AliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: AliasRouting -> Value # toEncoding :: AliasRouting -> Encoding # toJSONList :: [AliasRouting] -> Value # toEncodingList :: [AliasRouting] -> Encoding # | |
FromJSON AliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client |
newtype SearchAliasRouting Source #
Constructors
SearchAliasRouting (NonEmpty RoutingValue) |
Instances
Eq SearchAliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SearchAliasRouting -> SearchAliasRouting -> Bool # (/=) :: SearchAliasRouting -> SearchAliasRouting -> Bool # | |
Show SearchAliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SearchAliasRouting -> ShowS # show :: SearchAliasRouting -> String # showList :: [SearchAliasRouting] -> ShowS # | |
ToJSON SearchAliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: SearchAliasRouting -> Value # toEncoding :: SearchAliasRouting -> Encoding # toJSONList :: [SearchAliasRouting] -> Value # toEncodingList :: [SearchAliasRouting] -> Encoding # | |
FromJSON SearchAliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser SearchAliasRouting # parseJSONList :: Value -> Parser [SearchAliasRouting] # |
newtype IndexAliasRouting Source #
Constructors
IndexAliasRouting RoutingValue |
Instances
Eq IndexAliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexAliasRouting -> IndexAliasRouting -> Bool # (/=) :: IndexAliasRouting -> IndexAliasRouting -> Bool # | |
Show IndexAliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexAliasRouting -> ShowS # show :: IndexAliasRouting -> String # showList :: [IndexAliasRouting] -> ShowS # | |
ToJSON IndexAliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: IndexAliasRouting -> Value # toEncoding :: IndexAliasRouting -> Encoding # toJSONList :: [IndexAliasRouting] -> Value # toEncodingList :: [IndexAliasRouting] -> Encoding # | |
FromJSON IndexAliasRouting Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser IndexAliasRouting # parseJSONList :: Value -> Parser [IndexAliasRouting] # |
newtype RoutingValue Source #
Constructors
RoutingValue | |
Fields
|
Instances
Eq RoutingValue Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Show RoutingValue Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> RoutingValue -> ShowS # show :: RoutingValue -> String # showList :: [RoutingValue] -> ShowS # | |
ToJSON RoutingValue Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: RoutingValue -> Value # toEncoding :: RoutingValue -> Encoding # toJSONList :: [RoutingValue] -> Value # toEncodingList :: [RoutingValue] -> Encoding # | |
FromJSON RoutingValue Source # | |
Defined in Database.Bloodhound.Internal.Client |
newtype IndexAliasesSummary Source #
Constructors
IndexAliasesSummary | |
Fields |
Instances
Eq IndexAliasesSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexAliasesSummary -> IndexAliasesSummary -> Bool # (/=) :: IndexAliasesSummary -> IndexAliasesSummary -> Bool # | |
Show IndexAliasesSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexAliasesSummary -> ShowS # show :: IndexAliasesSummary -> String # showList :: [IndexAliasesSummary] -> ShowS # | |
FromJSON IndexAliasesSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser IndexAliasesSummary # parseJSONList :: Value -> Parser [IndexAliasesSummary] # |
data IndexAliasSummary Source #
IndexAliasSummary
is a summary of an index alias configured for a server.
Constructors
IndexAliasSummary | |
Instances
Eq IndexAliasSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexAliasSummary -> IndexAliasSummary -> Bool # (/=) :: IndexAliasSummary -> IndexAliasSummary -> Bool # | |
Show IndexAliasSummary Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexAliasSummary -> ShowS # show :: IndexAliasSummary -> String # showList :: [IndexAliasSummary] -> ShowS # |
newtype DocVersion Source #
DocVersion
is an integer version number for a document between 1
and 9.2e+18 used for .
Constructors
DocVersion | |
Fields |
Instances
mkDocVersion :: Int -> Maybe DocVersion Source #
Smart constructor for in-range doc version
newtype ExternalDocVersion Source #
ExternalDocVersion
is a convenience wrapper if your code uses its
own version numbers instead of ones from ES.
Constructors
ExternalDocVersion DocVersion |
Instances
data VersionControl Source #
VersionControl
is specified when indexing documents as a
optimistic concurrency control.
Constructors
NoVersionControl | Don't send a version. This is a pure overwrite. |
InternalVersion DocVersion | Use the default ES versioning scheme. Only index the document if the version is the same as the one specified. Only applicable to updates, as you should be getting Version from a search result. |
ExternalGT ExternalDocVersion | Use your own version numbering. Only index the document if the version is strictly higher OR the document doesn't exist. The given version will be used as the new version number for the stored document. N.B. All updates must increment this number, meaning there is some global, external ordering of updates. |
ExternalGTE ExternalDocVersion | Use your own version numbering. Only index the document if the version is equal or higher than the stored version. Will succeed if there is no existing document. The given version will be used as the new version number for the stored document. Use with care, as this could result in data loss. |
ForceVersion ExternalDocVersion | The document will always be indexed and the given version will be the new version. This is typically used for correcting errors. Use with care, as this could result in data loss. |
Instances
Eq VersionControl Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: VersionControl -> VersionControl -> Bool # (/=) :: VersionControl -> VersionControl -> Bool # | |
Ord VersionControl Source # | |
Defined in Database.Bloodhound.Internal.Client Methods compare :: VersionControl -> VersionControl -> Ordering # (<) :: VersionControl -> VersionControl -> Bool # (<=) :: VersionControl -> VersionControl -> Bool # (>) :: VersionControl -> VersionControl -> Bool # (>=) :: VersionControl -> VersionControl -> Bool # max :: VersionControl -> VersionControl -> VersionControl # min :: VersionControl -> VersionControl -> VersionControl # | |
Show VersionControl Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> VersionControl -> ShowS # show :: VersionControl -> String # showList :: [VersionControl] -> ShowS # |
data JoinRelation Source #
Instances
Eq JoinRelation Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Show JoinRelation Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JoinRelation -> ShowS # show :: JoinRelation -> String # showList :: [JoinRelation] -> ShowS # |
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
Eq IndexDocumentSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexDocumentSettings -> IndexDocumentSettings -> Bool # (/=) :: IndexDocumentSettings -> IndexDocumentSettings -> Bool # | |
Show IndexDocumentSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexDocumentSettings -> ShowS # show :: IndexDocumentSettings -> String # showList :: [IndexDocumentSettings] -> ShowS # |
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
Eq IndexSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: IndexSelection -> IndexSelection -> Bool # (/=) :: IndexSelection -> IndexSelection -> Bool # | |
Show IndexSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexSelection -> ShowS # show :: IndexSelection -> String # showList :: [IndexSelection] -> ShowS # |
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
Eq NodeSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeSelection -> NodeSelection -> Bool # (/=) :: NodeSelection -> NodeSelection -> Bool # | |
Show NodeSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeSelection -> ShowS # show :: NodeSelection -> String # showList :: [NodeSelection] -> ShowS # |
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
Eq NodeSelector Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Show NodeSelector Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeSelector -> ShowS # show :: NodeSelector -> String # showList :: [NodeSelector] -> ShowS # |
newtype TemplateName Source #
TemplateName
is used to describe which template to querycreatedelete
Constructors
TemplateName Text |
Instances
Eq TemplateName Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Show TemplateName Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> TemplateName -> ShowS # show :: TemplateName -> String # showList :: [TemplateName] -> ShowS # | |
ToJSON TemplateName Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: TemplateName -> Value # toEncoding :: TemplateName -> Encoding # toJSONList :: [TemplateName] -> Value # toEncodingList :: [TemplateName] -> Encoding # | |
FromJSON TemplateName Source # | |
Defined in Database.Bloodhound.Internal.Client |
newtype IndexPattern Source #
IndexPattern
represents a pattern which is matched against index names
Constructors
IndexPattern Text |
Instances
Eq IndexPattern Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Show IndexPattern Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> IndexPattern -> ShowS # show :: IndexPattern -> String # showList :: [IndexPattern] -> ShowS # | |
ToJSON IndexPattern Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: IndexPattern -> Value # toEncoding :: IndexPattern -> Encoding # toJSONList :: [IndexPattern] -> Value # toEncodingList :: [IndexPattern] -> Encoding # | |
FromJSON IndexPattern Source # | |
Defined in Database.Bloodhound.Internal.Client |
newtype EsUsername Source #
Username type used for HTTP Basic authentication. See basicAuthHook
.
Constructors
EsUsername | |
Fields
|
Instances
Eq EsUsername Source # | |
Defined in Database.Bloodhound.Internal.Client | |
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 # |
newtype EsPassword Source #
Password type used for HTTP Basic authentication. See basicAuthHook
.
Constructors
EsPassword | |
Fields
|
Instances
Eq EsPassword Source # | |
Defined in Database.Bloodhound.Internal.Client | |
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 # |
data SnapshotRepoSelection Source #
Constructors
SnapshotRepoList (NonEmpty SnapshotRepoPattern) | |
AllSnapshotRepos |
Instances
Eq SnapshotRepoSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotRepoSelection -> SnapshotRepoSelection -> Bool # (/=) :: SnapshotRepoSelection -> SnapshotRepoSelection -> Bool # | |
Show SnapshotRepoSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotRepoSelection -> ShowS # show :: SnapshotRepoSelection -> String # showList :: [SnapshotRepoSelection] -> ShowS # |
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
Eq SnapshotRepoPattern Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotRepoPattern -> SnapshotRepoPattern -> Bool # (/=) :: SnapshotRepoPattern -> SnapshotRepoPattern -> Bool # | |
Show SnapshotRepoPattern Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotRepoPattern -> ShowS # show :: SnapshotRepoPattern -> String # showList :: [SnapshotRepoPattern] -> ShowS # |
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
Eq GenericSnapshotRepo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: GenericSnapshotRepo -> GenericSnapshotRepo -> Bool # (/=) :: GenericSnapshotRepo -> GenericSnapshotRepo -> Bool # | |
Show GenericSnapshotRepo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> GenericSnapshotRepo -> ShowS # show :: GenericSnapshotRepo -> String # showList :: [GenericSnapshotRepo] -> ShowS # | |
SnapshotRepo GenericSnapshotRepo Source # | |
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
newtype SnapshotVerification Source #
The result of running verifySnapshotRepo
.
Constructors
SnapshotVerification | |
Instances
Eq SnapshotVerification Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotVerification -> SnapshotVerification -> Bool # (/=) :: SnapshotVerification -> SnapshotVerification -> Bool # | |
Show SnapshotVerification Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotVerification -> ShowS # show :: SnapshotVerification -> String # showList :: [SnapshotVerification] -> ShowS # | |
FromJSON SnapshotVerification Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser SnapshotVerification # parseJSONList :: Value -> Parser [SnapshotVerification] # |
data SnapshotNodeVerification Source #
A node that has verified a snapshot
Constructors
SnapshotNodeVerification | |
Fields |
Instances
Eq SnapshotNodeVerification Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotNodeVerification -> SnapshotNodeVerification -> Bool # (/=) :: SnapshotNodeVerification -> SnapshotNodeVerification -> Bool # | |
Show SnapshotNodeVerification Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotNodeVerification -> ShowS # show :: SnapshotNodeVerification -> String # showList :: [SnapshotNodeVerification] -> ShowS # |
newtype FullNodeId Source #
Unique, automatically-generated name assigned to nodes that are usually returned in node-oriented APIs.
Constructors
FullNodeId | |
Fields
|
Instances
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 # | |
Show FullNodeId Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> FullNodeId -> ShowS # show :: FullNodeId -> String # showList :: [FullNodeId] -> ShowS # | |
FromJSON FullNodeId Source # | |
Defined in Database.Bloodhound.Internal.Client |
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
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 # | |
Show ClusterName Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> ClusterName -> ShowS # show :: ClusterName -> String # showList :: [ClusterName] -> ShowS # | |
FromJSON ClusterName Source # | |
Defined in Database.Bloodhound.Internal.Client |
Constructors
NodesInfo | |
Fields
|
data NodesStats Source #
Constructors
NodesStats | |
Fields |
Instances
Eq 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 # | |
FromJSON NodesStats Source # | |
Defined in Database.Bloodhound.Internal.Client |
Constructors
data NodeBreakersStats Source #
Constructors
NodeBreakersStats | |
Instances
Eq NodeBreakersStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeBreakersStats -> NodeBreakersStats -> Bool # (/=) :: NodeBreakersStats -> NodeBreakersStats -> Bool # | |
Show NodeBreakersStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeBreakersStats -> ShowS # show :: NodeBreakersStats -> String # showList :: [NodeBreakersStats] -> ShowS # | |
FromJSON NodeBreakersStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeBreakersStats # parseJSONList :: Value -> Parser [NodeBreakersStats] # |
data NodeBreakerStats Source #
Constructors
NodeBreakerStats | |
Fields |
Instances
Eq NodeBreakerStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeBreakerStats -> NodeBreakerStats -> Bool # (/=) :: NodeBreakerStats -> NodeBreakerStats -> Bool # | |
Show NodeBreakerStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeBreakerStats -> ShowS # show :: NodeBreakerStats -> String # showList :: [NodeBreakerStats] -> ShowS # | |
FromJSON NodeBreakerStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeBreakerStats # parseJSONList :: Value -> Parser [NodeBreakerStats] # |
data NodeHTTPStats Source #
Constructors
NodeHTTPStats | |
Fields |
Instances
Eq NodeHTTPStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeHTTPStats -> NodeHTTPStats -> Bool # (/=) :: NodeHTTPStats -> NodeHTTPStats -> Bool # | |
Show NodeHTTPStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeHTTPStats -> ShowS # show :: NodeHTTPStats -> String # showList :: [NodeHTTPStats] -> ShowS # | |
FromJSON NodeHTTPStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeHTTPStats # parseJSONList :: Value -> Parser [NodeHTTPStats] # |
data NodeTransportStats Source #
Constructors
NodeTransportStats | |
Fields |
Instances
Eq NodeTransportStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeTransportStats -> NodeTransportStats -> Bool # (/=) :: NodeTransportStats -> NodeTransportStats -> Bool # | |
Show NodeTransportStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeTransportStats -> ShowS # show :: NodeTransportStats -> String # showList :: [NodeTransportStats] -> ShowS # | |
FromJSON NodeTransportStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeTransportStats # parseJSONList :: Value -> Parser [NodeTransportStats] # |
data NodeFSStats Source #
Constructors
NodeFSStats | |
Fields |
Instances
Eq 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 # | |
FromJSON NodeFSStats Source # | |
Defined in Database.Bloodhound.Internal.Client |
data NodeDataPathStats Source #
Constructors
Instances
Eq NodeDataPathStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeDataPathStats -> NodeDataPathStats -> Bool # (/=) :: NodeDataPathStats -> NodeDataPathStats -> Bool # | |
Show NodeDataPathStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeDataPathStats -> ShowS # show :: NodeDataPathStats -> String # showList :: [NodeDataPathStats] -> ShowS # | |
FromJSON NodeDataPathStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeDataPathStats # parseJSONList :: Value -> Parser [NodeDataPathStats] # |
data NodeFSTotalStats Source #
Constructors
Instances
Eq NodeFSTotalStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeFSTotalStats -> NodeFSTotalStats -> Bool # (/=) :: NodeFSTotalStats -> NodeFSTotalStats -> Bool # | |
Show NodeFSTotalStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeFSTotalStats -> ShowS # show :: NodeFSTotalStats -> String # showList :: [NodeFSTotalStats] -> ShowS # | |
FromJSON NodeFSTotalStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeFSTotalStats # parseJSONList :: Value -> Parser [NodeFSTotalStats] # |
data NodeNetworkStats Source #
Constructors
NodeNetworkStats | |
Instances
Eq NodeNetworkStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeNetworkStats -> NodeNetworkStats -> Bool # (/=) :: NodeNetworkStats -> NodeNetworkStats -> Bool # | |
Show NodeNetworkStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeNetworkStats -> ShowS # show :: NodeNetworkStats -> String # showList :: [NodeNetworkStats] -> ShowS # | |
FromJSON NodeNetworkStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeNetworkStats # parseJSONList :: Value -> Parser [NodeNetworkStats] # |
data NodeThreadPoolStats Source #
Constructors
NodeThreadPoolStats | |
Instances
Eq NodeThreadPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeThreadPoolStats -> NodeThreadPoolStats -> Bool # (/=) :: NodeThreadPoolStats -> NodeThreadPoolStats -> Bool # | |
Show NodeThreadPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeThreadPoolStats -> ShowS # show :: NodeThreadPoolStats -> String # showList :: [NodeThreadPoolStats] -> ShowS # | |
FromJSON NodeThreadPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeThreadPoolStats # parseJSONList :: Value -> Parser [NodeThreadPoolStats] # |
data NodeJVMStats Source #
Constructors
Instances
Eq 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 # | |
FromJSON NodeJVMStats Source # | |
Defined in Database.Bloodhound.Internal.Client |
data JVMBufferPoolStats Source #
Constructors
JVMBufferPoolStats | |
Instances
Eq JVMBufferPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: JVMBufferPoolStats -> JVMBufferPoolStats -> Bool # (/=) :: JVMBufferPoolStats -> JVMBufferPoolStats -> Bool # | |
Show JVMBufferPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JVMBufferPoolStats -> ShowS # show :: JVMBufferPoolStats -> String # showList :: [JVMBufferPoolStats] -> ShowS # | |
FromJSON JVMBufferPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser JVMBufferPoolStats # parseJSONList :: Value -> Parser [JVMBufferPoolStats] # |
data JVMGCStats Source #
Constructors
JVMGCStats | |
Instances
Eq 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 # | |
FromJSON JVMGCStats Source # | |
Defined in Database.Bloodhound.Internal.Client |
data JVMPoolStats Source #
Constructors
JVMPoolStats | |
Fields |
Instances
Eq 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 # | |
FromJSON JVMPoolStats Source # | |
Defined in Database.Bloodhound.Internal.Client |
data NodeProcessStats Source #
Constructors
NodeProcessStats | |
Instances
Eq NodeProcessStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeProcessStats -> NodeProcessStats -> Bool # (/=) :: NodeProcessStats -> NodeProcessStats -> Bool # | |
Show NodeProcessStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeProcessStats -> ShowS # show :: NodeProcessStats -> String # showList :: [NodeProcessStats] -> ShowS # | |
FromJSON NodeProcessStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeProcessStats # parseJSONList :: Value -> Parser [NodeProcessStats] # |
data NodeOSStats Source #
Constructors
NodeOSStats | |
Fields |
Instances
Eq 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 # | |
FromJSON NodeOSStats Source # | |
Defined in Database.Bloodhound.Internal.Client |
Constructors
LoadAvgs | |
Fields
|
data NodeIndicesStats Source #
Constructors
Instances
Eq NodeIndicesStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeIndicesStats -> NodeIndicesStats -> Bool # (/=) :: NodeIndicesStats -> NodeIndicesStats -> Bool # | |
Show NodeIndicesStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeIndicesStats -> ShowS # show :: NodeIndicesStats -> String # showList :: [NodeIndicesStats] -> ShowS # | |
FromJSON NodeIndicesStats Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeIndicesStats # parseJSONList :: Value -> Parser [NodeIndicesStats] # |
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
Eq EsAddress Source # | |
Ord EsAddress Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Show EsAddress Source # | |
FromJSON EsAddress Source # | |
Typically a 7 character hex string.
Instances
newtype PluginName Source #
Constructors
PluginName | |
Fields
|
Instances
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 # | |
Show PluginName Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> PluginName -> ShowS # show :: PluginName -> String # showList :: [PluginName] -> ShowS # | |
FromJSON PluginName Source # | |
Defined in Database.Bloodhound.Internal.Client |
Constructors
NodeInfo | |
Fields
|
data NodePluginInfo Source #
Constructors
NodePluginInfo | |
Fields
|
Instances
Eq NodePluginInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodePluginInfo -> NodePluginInfo -> Bool # (/=) :: NodePluginInfo -> NodePluginInfo -> Bool # | |
Show NodePluginInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodePluginInfo -> ShowS # show :: NodePluginInfo -> String # showList :: [NodePluginInfo] -> ShowS # | |
FromJSON NodePluginInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodePluginInfo # parseJSONList :: Value -> Parser [NodePluginInfo] # |
data NodeHTTPInfo Source #
Constructors
NodeHTTPInfo | |
Instances
Eq 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 # | |
FromJSON NodeHTTPInfo Source # | |
Defined in Database.Bloodhound.Internal.Client |
data NodeTransportInfo Source #
Constructors
NodeTransportInfo | |
Instances
Eq NodeTransportInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeTransportInfo -> NodeTransportInfo -> Bool # (/=) :: NodeTransportInfo -> NodeTransportInfo -> Bool # | |
Show NodeTransportInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeTransportInfo -> ShowS # show :: NodeTransportInfo -> String # showList :: [NodeTransportInfo] -> ShowS # | |
FromJSON NodeTransportInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeTransportInfo # parseJSONList :: Value -> Parser [NodeTransportInfo] # |
data BoundTransportAddress Source #
Constructors
BoundTransportAddress | |
Fields
|
Instances
Eq BoundTransportAddress Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: BoundTransportAddress -> BoundTransportAddress -> Bool # (/=) :: BoundTransportAddress -> BoundTransportAddress -> Bool # | |
Show BoundTransportAddress Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> BoundTransportAddress -> ShowS # show :: BoundTransportAddress -> String # showList :: [BoundTransportAddress] -> ShowS # | |
FromJSON BoundTransportAddress Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser BoundTransportAddress # parseJSONList :: Value -> Parser [BoundTransportAddress] # |
data NodeNetworkInfo Source #
Constructors
NodeNetworkInfo | |
Instances
Eq NodeNetworkInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeNetworkInfo -> NodeNetworkInfo -> Bool # (/=) :: NodeNetworkInfo -> NodeNetworkInfo -> Bool # | |
Show NodeNetworkInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeNetworkInfo -> ShowS # show :: NodeNetworkInfo -> String # showList :: [NodeNetworkInfo] -> ShowS # | |
FromJSON NodeNetworkInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeNetworkInfo # parseJSONList :: Value -> Parser [NodeNetworkInfo] # |
newtype MacAddress Source #
Constructors
MacAddress | |
Fields
|
Instances
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 # | |
Show MacAddress Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> MacAddress -> ShowS # show :: MacAddress -> String # showList :: [MacAddress] -> ShowS # | |
FromJSON MacAddress Source # | |
Defined in Database.Bloodhound.Internal.Client |
newtype NetworkInterfaceName Source #
Constructors
NetworkInterfaceName | |
Fields |
Instances
data NodeNetworkInterface Source #
Constructors
NodeNetworkInterface | |
Instances
Eq NodeNetworkInterface Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeNetworkInterface -> NodeNetworkInterface -> Bool # (/=) :: NodeNetworkInterface -> NodeNetworkInterface -> Bool # | |
Show NodeNetworkInterface Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeNetworkInterface -> ShowS # show :: NodeNetworkInterface -> String # showList :: [NodeNetworkInterface] -> ShowS # | |
FromJSON NodeNetworkInterface Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeNetworkInterface # parseJSONList :: Value -> Parser [NodeNetworkInterface] # |
data ThreadPool Source #
Constructors
ThreadPool | |
Fields |
Instances
Eq ThreadPool Source # | |
Defined in Database.Bloodhound.Internal.Client | |
Show ThreadPool Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> ThreadPool -> ShowS # show :: ThreadPool -> String # showList :: [ThreadPool] -> ShowS # |
data NodeThreadPoolInfo Source #
Constructors
NodeThreadPoolInfo | |
Instances
Eq NodeThreadPoolInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeThreadPoolInfo -> NodeThreadPoolInfo -> Bool # (/=) :: NodeThreadPoolInfo -> NodeThreadPoolInfo -> Bool # | |
Show NodeThreadPoolInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeThreadPoolInfo -> ShowS # show :: NodeThreadPoolInfo -> String # showList :: [NodeThreadPoolInfo] -> ShowS # | |
FromJSON NodeThreadPoolInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeThreadPoolInfo # parseJSONList :: Value -> Parser [NodeThreadPoolInfo] # |
data ThreadPoolSize Source #
Constructors
ThreadPoolBounded Int | |
ThreadPoolUnbounded |
Instances
Eq ThreadPoolSize Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: ThreadPoolSize -> ThreadPoolSize -> Bool # (/=) :: ThreadPoolSize -> ThreadPoolSize -> Bool # | |
Show ThreadPoolSize Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> ThreadPoolSize -> ShowS # show :: ThreadPoolSize -> String # showList :: [ThreadPoolSize] -> ShowS # | |
FromJSON ThreadPoolSize Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser ThreadPoolSize # parseJSONList :: Value -> Parser [ThreadPoolSize] # |
data ThreadPoolType Source #
Instances
Eq ThreadPoolType Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: ThreadPoolType -> ThreadPoolType -> Bool # (/=) :: ThreadPoolType -> ThreadPoolType -> Bool # | |
Show ThreadPoolType Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> ThreadPoolType -> ShowS # show :: ThreadPoolType -> String # showList :: [ThreadPoolType] -> ShowS # | |
FromJSON ThreadPoolType Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser ThreadPoolType # parseJSONList :: Value -> Parser [ThreadPoolType] # |
data NodeJVMInfo Source #
Constructors
NodeJVMInfo | |
Fields
|
Instances
Eq 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 # | |
FromJSON 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
Eq 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 # | |
FromJSON JVMVersion Source # | |
Defined in Database.Bloodhound.Internal.Client |
data JVMMemoryInfo Source #
Constructors
JVMMemoryInfo | |
Instances
Eq JVMMemoryInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: JVMMemoryInfo -> JVMMemoryInfo -> Bool # (/=) :: JVMMemoryInfo -> JVMMemoryInfo -> Bool # | |
Show JVMMemoryInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JVMMemoryInfo -> ShowS # show :: JVMMemoryInfo -> String # showList :: [JVMMemoryInfo] -> ShowS # | |
FromJSON JVMMemoryInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser JVMMemoryInfo # parseJSONList :: Value -> Parser [JVMMemoryInfo] # |
Constructors
VMVersion | |
Fields
|
newtype JVMMemoryPool Source #
Constructors
JVMMemoryPool | |
Fields |
Instances
Eq JVMMemoryPool Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: JVMMemoryPool -> JVMMemoryPool -> Bool # (/=) :: JVMMemoryPool -> JVMMemoryPool -> Bool # | |
Show JVMMemoryPool Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JVMMemoryPool -> ShowS # show :: JVMMemoryPool -> String # showList :: [JVMMemoryPool] -> ShowS # | |
FromJSON JVMMemoryPool Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser JVMMemoryPool # parseJSONList :: Value -> Parser [JVMMemoryPool] # |
newtype JVMGCCollector Source #
Constructors
JVMGCCollector | |
Fields |
Instances
Eq JVMGCCollector Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: JVMGCCollector -> JVMGCCollector -> Bool # (/=) :: JVMGCCollector -> JVMGCCollector -> Bool # | |
Show JVMGCCollector Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> JVMGCCollector -> ShowS # show :: JVMGCCollector -> String # showList :: [JVMGCCollector] -> ShowS # | |
FromJSON JVMGCCollector Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser JVMGCCollector # parseJSONList :: Value -> Parser [JVMGCCollector] # |
data NodeOSInfo Source #
Constructors
NodeOSInfo | |
Fields |
Instances
Eq 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 # | |
FromJSON NodeOSInfo Source # | |
Defined in Database.Bloodhound.Internal.Client |
Constructors
CPUInfo | |
Fields
|
data NodeProcessInfo Source #
Constructors
NodeProcessInfo | |
Instances
Eq NodeProcessInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: NodeProcessInfo -> NodeProcessInfo -> Bool # (/=) :: NodeProcessInfo -> NodeProcessInfo -> Bool # | |
Show NodeProcessInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> NodeProcessInfo -> ShowS # show :: NodeProcessInfo -> String # showList :: [NodeProcessInfo] -> ShowS # | |
FromJSON NodeProcessInfo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser NodeProcessInfo # parseJSONList :: Value -> Parser [NodeProcessInfo] # |
data ShardResult Source #
Constructors
ShardResult | |
Fields
|
Instances
Eq 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 # | |
FromJSON ShardResult Source # | |
Defined in Database.Bloodhound.Internal.Client |
data SnapshotState Source #
Constructors
SnapshotInit | |
SnapshotStarted | |
SnapshotSuccess | |
SnapshotFailed | |
SnapshotAborted | |
SnapshotMissing | |
SnapshotWaiting |
Instances
Eq SnapshotState Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotState -> SnapshotState -> Bool # (/=) :: SnapshotState -> SnapshotState -> Bool # | |
Show SnapshotState Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotState -> ShowS # show :: SnapshotState -> String # showList :: [SnapshotState] -> ShowS # | |
FromJSON SnapshotState Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser SnapshotState # parseJSONList :: Value -> Parser [SnapshotState] # |
data SnapshotRestoreSettings Source #
Constructors
SnapshotRestoreSettings | |
Fields
|
Instances
Eq SnapshotRestoreSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotRestoreSettings -> SnapshotRestoreSettings -> Bool # (/=) :: SnapshotRestoreSettings -> SnapshotRestoreSettings -> Bool # | |
Show SnapshotRestoreSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotRestoreSettings -> ShowS # show :: SnapshotRestoreSettings -> String # showList :: [SnapshotRestoreSettings] -> ShowS # |
newtype SnapshotRepoUpdateSettings Source #
Constructors
SnapshotRepoUpdateSettings | |
Fields
|
Instances
Eq SnapshotRepoUpdateSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotRepoUpdateSettings -> SnapshotRepoUpdateSettings -> Bool # (/=) :: SnapshotRepoUpdateSettings -> SnapshotRepoUpdateSettings -> Bool # | |
Show SnapshotRepoUpdateSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotRepoUpdateSettings -> ShowS # show :: SnapshotRepoUpdateSettings -> String # showList :: [SnapshotRepoUpdateSettings] -> ShowS # |
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
Eq FsSnapshotRepo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: FsSnapshotRepo -> FsSnapshotRepo -> Bool # (/=) :: FsSnapshotRepo -> FsSnapshotRepo -> Bool # | |
Show FsSnapshotRepo Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> FsSnapshotRepo -> ShowS # show :: FsSnapshotRepo -> String # showList :: [FsSnapshotRepo] -> ShowS # | |
SnapshotRepo FsSnapshotRepo Source # | |
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
Eq SnapshotRepoConversionError Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotRepoConversionError -> SnapshotRepoConversionError -> Bool # (/=) :: SnapshotRepoConversionError -> SnapshotRepoConversionError -> Bool # | |
Show SnapshotRepoConversionError Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotRepoConversionError -> ShowS # show :: SnapshotRepoConversionError -> String # showList :: [SnapshotRepoConversionError] -> ShowS # | |
Exception SnapshotRepoConversionError Source # | |
data SnapshotCreateSettings Source #
Constructors
SnapshotCreateSettings | |
Fields
|
Instances
Eq SnapshotCreateSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotCreateSettings -> SnapshotCreateSettings -> Bool # (/=) :: SnapshotCreateSettings -> SnapshotCreateSettings -> Bool # | |
Show SnapshotCreateSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotCreateSettings -> ShowS # show :: SnapshotCreateSettings -> String # showList :: [SnapshotCreateSettings] -> ShowS # |
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
Eq SnapshotSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotSelection -> SnapshotSelection -> Bool # (/=) :: SnapshotSelection -> SnapshotSelection -> Bool # | |
Show SnapshotSelection Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotSelection -> ShowS # show :: SnapshotSelection -> String # showList :: [SnapshotSelection] -> ShowS # |
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
Eq SnapshotPattern Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotPattern -> SnapshotPattern -> Bool # (/=) :: SnapshotPattern -> SnapshotPattern -> Bool # | |
Show SnapshotPattern Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotPattern -> ShowS # show :: SnapshotPattern -> String # showList :: [SnapshotPattern] -> ShowS # |
data SnapshotInfo Source #
General information about the state of a snapshot. Has some
redundancies with SnapshotStatus
Constructors
SnapshotInfo | |
Instances
Eq 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 # | |
FromJSON SnapshotInfo Source # | |
Defined in Database.Bloodhound.Internal.Client |
data SnapshotShardFailure Source #
Constructors
SnapshotShardFailure | |
Instances
Eq SnapshotShardFailure Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: SnapshotShardFailure -> SnapshotShardFailure -> Bool # (/=) :: SnapshotShardFailure -> SnapshotShardFailure -> Bool # | |
Show SnapshotShardFailure Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> SnapshotShardFailure -> ShowS # show :: SnapshotShardFailure -> String # showList :: [SnapshotShardFailure] -> ShowS # | |
FromJSON SnapshotShardFailure Source # | |
Defined in Database.Bloodhound.Internal.Client Methods parseJSON :: Value -> Parser SnapshotShardFailure # parseJSONList :: Value -> Parser [SnapshotShardFailure] # |
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
Eq RestoreRenameToken Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: RestoreRenameToken -> RestoreRenameToken -> Bool # (/=) :: RestoreRenameToken -> RestoreRenameToken -> Bool # | |
Show RestoreRenameToken Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> RestoreRenameToken -> ShowS # show :: RestoreRenameToken -> String # showList :: [RestoreRenameToken] -> ShowS # |
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 | |
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 # | |
Show RRGroupRefNum Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> RRGroupRefNum -> ShowS # show :: RRGroupRefNum -> String # showList :: [RRGroupRefNum] -> ShowS # |
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
Eq RestoreIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods (==) :: RestoreIndexSettings -> RestoreIndexSettings -> Bool # (/=) :: RestoreIndexSettings -> RestoreIndexSettings -> Bool # | |
Show RestoreIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods showsPrec :: Int -> RestoreIndexSettings -> ShowS # show :: RestoreIndexSettings -> String # showList :: [RestoreIndexSettings] -> ShowS # | |
ToJSON RestoreIndexSettings Source # | |
Defined in Database.Bloodhound.Internal.Client Methods toJSON :: RestoreIndexSettings -> Value # toEncoding :: RestoreIndexSettings -> Encoding # toJSONList :: [RestoreIndexSettings] -> Value # toEncodingList :: [RestoreIndexSettings] -> Encoding # |
parseNodeStats :: FullNodeId -> Object -> Parser NodeStats Source #
parseNodeInfo :: FullNodeId -> Object -> Parser NodeInfo Source #
data TimeInterval Source #
Instances
Eq TimeInterval Source # | |
Defined in Database.Bloodhound.Internal.Client | |
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 # |
parseStringInterval :: (Monad m, MonadFail m) => String -> m NominalDiffTime Source #