| Copyright | (C) 2014 2018 Chris Allen |
|---|---|
| License | BSD-style (see the file LICENSE) |
| Maintainer | Chris Allen <cma@bitemyapp.com |
| Stability | provisional |
| Portability | RecordWildCards |
| Safe Haskell | None |
| Language | Haskell2010 |
Database.Bloodhound.Types
Description
Data types for describing actions and data structures performed to interact
with Elasticsearch. The two main buckets your queries against Elasticsearch
will fall into are Querys and Filters. Filters are more like
traditional database constraints and often have preferable performance
properties. Querys support human-written textual queries, such as fuzzy
queries.
Synopsis
- defaultCache :: Cache
- defaultIndexSettings :: IndexSettings
- defaultIndexMappingsLimits :: IndexMappingsLimits
- defaultIndexDocumentSettings :: IndexDocumentSettings
- mkSort :: FieldName -> SortOrder -> DefaultSort
- showText :: Show a => a -> Text
- unpackId :: DocId -> Text
- mkMatchQuery :: FieldName -> QueryString -> MatchQuery
- mkMultiMatchQuery :: [FieldName] -> QueryString -> MultiMatchQuery
- mkBoolQuery :: [Query] -> [Filter] -> [Query] -> [Query] -> BoolQuery
- mkRangeQuery :: FieldName -> RangeValue -> RangeQuery
- mkQueryStringQuery :: QueryString -> QueryStringQuery
- mkAggregations :: Key -> Aggregation -> Aggregations
- mkTermsAggregation :: Text -> TermsAggregation
- mkTermsScriptAggregation :: Text -> TermsAggregation
- mkDateHistogram :: FieldName -> Interval -> DateHistogramAggregation
- mkCardinalityAggregation :: FieldName -> CardinalityAggregation
- mkDocVersion :: Int -> Maybe DocVersion
- mkStatsAggregation :: FieldName -> StatisticsAggregation
- mkExtendedStatsAggregation :: FieldName -> StatisticsAggregation
- docVersionNumber :: DocVersion -> Int
- toMissing :: Key -> AggregationResults -> Maybe MissingResult
- toTerms :: Key -> AggregationResults -> Maybe (Bucket TermsResult)
- toDateHistogram :: Key -> AggregationResults -> Maybe (Bucket DateHistogramResult)
- toTopHits :: FromJSON a => Key -> AggregationResults -> Maybe (TopHitResult a)
- omitNulls :: [(Key, Value)] -> Value
- newtype BH m a = BH {}
- runBH :: BHEnv -> BH m a -> m a
- data BHEnv
- bhServer :: BHEnv -> Server
- bhManager :: BHEnv -> Manager
- bhRequestHook :: BHEnv -> Request -> IO Request
- mkBHEnv :: Server -> Manager -> BHEnv
- class (Functor m, Applicative m, MonadIO m) => MonadBH m where
- data Version = Version {}
- newtype VersionNumber = VersionNumber {}
- newtype MaybeNA a = MaybeNA {}
- newtype BuildHash = BuildHash {}
- data Status = Status {
- name :: Text
- cluster_name :: Text
- cluster_uuid :: Text
- version :: Version
- tagline :: Text
- newtype Existence = Existence Bool
- newtype NullValue = NullValue Bool
- data IndexMappingsLimits = IndexMappingsLimits {}
- data IndexSettings = IndexSettings {}
- 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
- data IndexSettingsSummary = IndexSettingsSummary {}
- data AllocationPolicy
- data Compression
- data ReplicaBounds
- 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
- data IndexTemplate = IndexTemplate {}
- newtype Server = Server Text
- type Reply = Response LByteString
- 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 {}
- newtype IndexAliasName = IndexAliasName {}
- data IndexAliasAction
- data IndexAliasCreate = IndexAliasCreate {}
- data IndexAliasSummary = IndexAliasSummary {}
- newtype IndexAliasesSummary = IndexAliasesSummary {}
- data AliasRouting
- newtype SearchAliasRouting = SearchAliasRouting (NonEmpty RoutingValue)
- newtype IndexAliasRouting = IndexAliasRouting RoutingValue
- newtype RoutingValue = RoutingValue {
- routingValue :: Text
- data DocVersion
- newtype ExternalDocVersion = ExternalDocVersion DocVersion
- data VersionControl
- data JoinRelation
- data IndexDocumentSettings = IndexDocumentSettings {}
- data Query
- = TermQuery Term (Maybe Boost)
- | TermsQuery Key (NonEmpty Text)
- | QueryMatchQuery MatchQuery
- | QueryMultiMatchQuery MultiMatchQuery
- | QueryBoolQuery BoolQuery
- | QueryBoostingQuery BoostingQuery
- | QueryCommonTermsQuery CommonTermsQuery
- | ConstantScoreQuery Query Boost
- | QueryFunctionScoreQuery FunctionScoreQuery
- | QueryDisMaxQuery DisMaxQuery
- | QueryFuzzyLikeThisQuery FuzzyLikeThisQuery
- | QueryFuzzyLikeFieldQuery FuzzyLikeFieldQuery
- | QueryFuzzyQuery FuzzyQuery
- | QueryHasChildQuery HasChildQuery
- | QueryHasParentQuery HasParentQuery
- | IdsQuery [DocId]
- | QueryIndicesQuery IndicesQuery
- | MatchAllQuery (Maybe Boost)
- | QueryMoreLikeThisQuery MoreLikeThisQuery
- | QueryMoreLikeThisFieldQuery MoreLikeThisFieldQuery
- | QueryNestedQuery NestedQuery
- | QueryPrefixQuery PrefixQuery
- | QueryQueryStringQuery QueryStringQuery
- | QuerySimpleQueryStringQuery SimpleQueryStringQuery
- | QueryRangeQuery RangeQuery
- | QueryRegexpQuery RegexpQuery
- | QueryExistsQuery FieldName
- | QueryMatchNoneQuery
- | QueryWildcardQuery WildcardQuery
- data Search = Search {
- queryBody :: Maybe Query
- filterBody :: Maybe Filter
- sortBody :: Maybe Sort
- aggBody :: Maybe Aggregations
- highlight :: Maybe Highlights
- trackSortScores :: TrackSortScores
- from :: From
- size :: Size
- searchType :: SearchType
- searchAfterKey :: Maybe SearchAfterKey
- fields :: Maybe [FieldName]
- scriptFields :: Maybe ScriptFields
- source :: Maybe Source
- suggestBody :: Maybe Suggest
- data SearchType
- data SearchResult a = SearchResult {}
- newtype ScrollId = ScrollId Text
- data HitsTotalRelation
- data HitsTotal = HitsTotal {}
- data SearchHits a = SearchHits {}
- type TrackSortScores = Bool
- newtype From = From Int
- newtype Size = Size Int
- data Source
- data PatternOrPatterns
- data Include = Include [Pattern]
- data Exclude = Exclude [Pattern]
- newtype Pattern = Pattern Text
- data ShardResult = ShardResult {
- shardTotal :: Int
- shardsSuccessful :: Int
- shardsSkipped :: Int
- shardsFailed :: Int
- data Hit a = Hit {
- hitIndex :: IndexName
- hitDocId :: DocId
- hitScore :: Score
- hitSource :: Maybe a
- hitSort :: Maybe SearchAfterKey
- hitFields :: Maybe HitFields
- hitHighlight :: Maybe HitHighlight
- hitInnerHits :: Maybe (KeyMap (TopHitResult Value))
- newtype HitFields = HitFields (Map Text [Value])
- newtype Filter = Filter {}
- data BoolMatch
- data Term = Term {}
- data GeoPoint = GeoPoint {}
- data GeoBoundingBoxConstraint = GeoBoundingBoxConstraint {}
- data GeoBoundingBox = GeoBoundingBox {
- topLeft :: LatLon
- bottomRight :: LatLon
- data GeoFilterType
- data Distance = Distance {}
- data DistanceUnit
- = Miles
- | Yards
- | Feet
- | Inches
- | Kilometers
- | Meters
- | Centimeters
- | Millimeters
- | NauticalMiles
- data DistanceType
- data DistanceRange = DistanceRange {}
- data OptimizeBbox
- data LatLon = LatLon {}
- data RangeValue
- = RangeDateLte LessThanEqD
- | RangeDateLt LessThanD
- | RangeDateGte GreaterThanEqD
- | RangeDateGt GreaterThanD
- | RangeDateGtLt GreaterThanD LessThanD
- | RangeDateGteLte GreaterThanEqD LessThanEqD
- | RangeDateGteLt GreaterThanEqD LessThanD
- | RangeDateGtLte GreaterThanD LessThanEqD
- | RangeDoubleLte LessThanEq
- | RangeDoubleLt LessThan
- | RangeDoubleGte GreaterThanEq
- | RangeDoubleGt GreaterThan
- | RangeDoubleGtLt GreaterThan LessThan
- | RangeDoubleGteLte GreaterThanEq LessThanEq
- | RangeDoubleGteLt GreaterThanEq LessThan
- | RangeDoubleGtLte GreaterThan LessThanEq
- data RangeExecution
- newtype LessThan = LessThan Double
- newtype LessThanEq = LessThanEq Double
- newtype GreaterThan = GreaterThan Double
- newtype GreaterThanEq = GreaterThanEq Double
- newtype LessThanD = LessThanD UTCTime
- newtype LessThanEqD = LessThanEqD UTCTime
- newtype GreaterThanD = GreaterThanD UTCTime
- newtype GreaterThanEqD = GreaterThanEqD UTCTime
- newtype Regexp = Regexp Text
- data RegexpFlags
- data RegexpFlag
- newtype FieldName = FieldName Text
- newtype ScriptFields = ScriptFields (KeyMap ScriptFieldValue)
- type ScriptFieldValue = Value
- data Script = Script {}
- newtype ScriptLanguage = ScriptLanguage Text
- data ScriptSource
- newtype ScriptParams = ScriptParams (KeyMap ScriptParamValue)
- type ScriptParamValue = Value
- newtype IndexName = IndexName Text
- data IndexSelection
- data NodeSelection
- data NodeSelector
- data ForceMergeIndexSettings = ForceMergeIndexSettings {}
- defaultForceMergeIndexSettings :: ForceMergeIndexSettings
- newtype TemplateName = TemplateName Text
- newtype IndexPattern = IndexPattern Text
- newtype DocId = DocId Text
- newtype CacheName = CacheName Text
- newtype CacheKey = CacheKey Text
- 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]
- newtype ReplicaCount = ReplicaCount Int
- newtype ShardCount = ShardCount Int
- type Sort = [SortSpec]
- data SortMode
- data SortOrder
- data SortSpec
- data DefaultSort = DefaultSort {}
- data Missing
- data OpenCloseIndex
- type Method = Method
- newtype Boost = Boost Double
- data MatchQuery = MatchQuery {
- matchQueryField :: FieldName
- matchQueryQueryString :: QueryString
- matchQueryOperator :: BooleanOperator
- matchQueryZeroTerms :: ZeroTermsQuery
- matchQueryCutoffFrequency :: Maybe CutoffFrequency
- matchQueryMatchType :: Maybe MatchQueryType
- matchQueryAnalyzer :: Maybe Analyzer
- matchQueryMaxExpansions :: Maybe MaxExpansions
- matchQueryLenient :: Maybe Lenient
- matchQueryBoost :: Maybe Boost
- matchQueryMinimumShouldMatch :: Maybe Text
- matchQueryFuzziness :: Maybe Fuzziness
- data MultiMatchQuery = MultiMatchQuery {
- multiMatchQueryFields :: [FieldName]
- multiMatchQueryString :: QueryString
- multiMatchQueryOperator :: BooleanOperator
- multiMatchQueryZeroTerms :: ZeroTermsQuery
- multiMatchQueryTiebreaker :: Maybe Tiebreaker
- multiMatchQueryType :: Maybe MultiMatchQueryType
- multiMatchQueryCutoffFrequency :: Maybe CutoffFrequency
- multiMatchQueryAnalyzer :: Maybe Analyzer
- multiMatchQueryMaxExpansions :: Maybe MaxExpansions
- multiMatchQueryLenient :: Maybe Lenient
- data BoolQuery = BoolQuery {}
- data BoostingQuery = BoostingQuery {}
- data CommonTermsQuery = CommonTermsQuery {
- commonField :: FieldName
- commonQuery :: QueryString
- commonCutoffFrequency :: CutoffFrequency
- commonLowFreqOperator :: BooleanOperator
- commonHighFreqOperator :: BooleanOperator
- commonMinimumShouldMatch :: Maybe CommonMinimumMatch
- commonBoost :: Maybe Boost
- commonAnalyzer :: Maybe Analyzer
- commonDisableCoord :: Maybe DisableCoord
- data FunctionScoreQuery = FunctionScoreQuery {}
- data BoostMode
- data ScoreMode
- data FunctionScoreFunctions
- data ComponentFunctionScoreFunction = ComponentFunctionScoreFunction {}
- data FunctionScoreFunction
- newtype Weight = Weight Float
- newtype Seed = Seed Float
- data FieldValueFactor = FieldValueFactor {}
- newtype Factor = Factor Float
- data FactorModifier
- newtype FactorMissingFieldValue = FactorMissingFieldValue Float
- data DisMaxQuery = DisMaxQuery {}
- data FuzzyLikeThisQuery = FuzzyLikeThisQuery {}
- data FuzzyLikeFieldQuery = FuzzyLikeFieldQuery {}
- data FuzzyQuery = FuzzyQuery {}
- data HasChildQuery = HasChildQuery {}
- data HasParentQuery = HasParentQuery {}
- data IndicesQuery = IndicesQuery {}
- data MoreLikeThisQuery = MoreLikeThisQuery {
- moreLikeThisText :: Text
- moreLikeThisFields :: Maybe (NonEmpty FieldName)
- moreLikeThisPercentMatch :: Maybe PercentMatch
- moreLikeThisMinimumTermFreq :: Maybe MinimumTermFrequency
- moreLikeThisMaxQueryTerms :: Maybe MaxQueryTerms
- moreLikeThisStopWords :: Maybe (NonEmpty StopWord)
- moreLikeThisMinDocFrequency :: Maybe MinDocFrequency
- moreLikeThisMaxDocFrequency :: Maybe MaxDocFrequency
- moreLikeThisMinWordLength :: Maybe MinWordLength
- moreLikeThisMaxWordLength :: Maybe MaxWordLength
- moreLikeThisBoostTerms :: Maybe BoostTerms
- moreLikeThisBoost :: Maybe Boost
- moreLikeThisAnalyzer :: Maybe Analyzer
- data MoreLikeThisFieldQuery = MoreLikeThisFieldQuery {
- moreLikeThisFieldText :: Text
- moreLikeThisFieldFields :: FieldName
- moreLikeThisFieldPercentMatch :: Maybe PercentMatch
- moreLikeThisFieldMinimumTermFreq :: Maybe MinimumTermFrequency
- moreLikeThisFieldMaxQueryTerms :: Maybe MaxQueryTerms
- moreLikeThisFieldStopWords :: Maybe (NonEmpty StopWord)
- moreLikeThisFieldMinDocFrequency :: Maybe MinDocFrequency
- moreLikeThisFieldMaxDocFrequency :: Maybe MaxDocFrequency
- moreLikeThisFieldMinWordLength :: Maybe MinWordLength
- moreLikeThisFieldMaxWordLength :: Maybe MaxWordLength
- moreLikeThisFieldBoostTerms :: Maybe BoostTerms
- moreLikeThisFieldBoost :: Maybe Boost
- moreLikeThisFieldAnalyzer :: Maybe Analyzer
- data NestedQuery = NestedQuery {}
- data PrefixQuery = PrefixQuery {}
- data QueryStringQuery = QueryStringQuery {
- queryStringQuery :: QueryString
- queryStringDefaultField :: Maybe FieldName
- queryStringOperator :: Maybe BooleanOperator
- queryStringAnalyzer :: Maybe Analyzer
- queryStringAllowLeadingWildcard :: Maybe AllowLeadingWildcard
- queryStringLowercaseExpanded :: Maybe LowercaseExpanded
- queryStringEnablePositionIncrements :: Maybe EnablePositionIncrements
- queryStringFuzzyMaxExpansions :: Maybe MaxExpansions
- queryStringFuzziness :: Maybe Fuzziness
- queryStringFuzzyPrefixLength :: Maybe PrefixLength
- queryStringPhraseSlop :: Maybe PhraseSlop
- queryStringBoost :: Maybe Boost
- queryStringAnalyzeWildcard :: Maybe AnalyzeWildcard
- queryStringGeneratePhraseQueries :: Maybe GeneratePhraseQueries
- queryStringMinimumShouldMatch :: Maybe MinimumMatch
- queryStringLenient :: Maybe Lenient
- queryStringLocale :: Maybe Locale
- data SimpleQueryStringQuery = SimpleQueryStringQuery {
- simpleQueryStringQuery :: QueryString
- simpleQueryStringField :: Maybe FieldOrFields
- simpleQueryStringOperator :: Maybe BooleanOperator
- simpleQueryStringAnalyzer :: Maybe Analyzer
- simpleQueryStringFlags :: Maybe (NonEmpty SimpleQueryFlag)
- simpleQueryStringLowercaseExpanded :: Maybe LowercaseExpanded
- simpleQueryStringLocale :: Maybe Locale
- data RangeQuery = RangeQuery {}
- data RegexpQuery = RegexpQuery {}
- newtype QueryString = QueryString Text
- newtype SearchTemplateId = SearchTemplateId Text
- newtype SearchTemplateSource = SearchTemplateSource Text
- data SearchTemplate = SearchTemplate {}
- data GetTemplateScript = GetTemplateScript {}
- newtype TemplateQueryKeyValuePairs = TemplateQueryKeyValuePairs (KeyMap TemplateQueryValue)
- data WildcardQuery = WildcardQuery {}
- data BooleanOperator
- data ZeroTermsQuery
- newtype CutoffFrequency = CutoffFrequency Double
- newtype Analyzer = Analyzer Text
- newtype Tokenizer = Tokenizer Text
- newtype TokenFilter = TokenFilter Text
- newtype CharFilter = CharFilter Text
- newtype MaxExpansions = MaxExpansions Int
- newtype Lenient = Lenient Bool
- data MatchQueryType
- data MultiMatchQueryType
- newtype Tiebreaker = Tiebreaker Double
- newtype MinimumMatch = MinimumMatch Int
- newtype DisableCoord = DisableCoord Bool
- data CommonMinimumMatch
- data MinimumMatchHighLow = MinimumMatchHighLow {}
- newtype PrefixLength = PrefixLength Int
- data Fuzziness
- newtype IgnoreTermFrequency = IgnoreTermFrequency Bool
- newtype MaxQueryTerms = MaxQueryTerms Int
- newtype AggregateParentScore = AggregateParentScore Bool
- newtype IgnoreUnmapped = IgnoreUnmapped Bool
- newtype MinChildren = MinChildren Int
- newtype MaxChildren = MaxChildren Int
- data ScoreType
- data InnerHits = InnerHits {}
- type Score = Maybe Double
- type Cache = Bool
- newtype RelationName = RelationName Text
- newtype BoostTerms = BoostTerms Double
- newtype MaxWordLength = MaxWordLength Int
- newtype MinWordLength = MinWordLength Int
- newtype MaxDocFrequency = MaxDocFrequency Int
- newtype MinDocFrequency = MinDocFrequency Int
- newtype PhraseSlop = PhraseSlop Int
- newtype StopWord = StopWord Text
- newtype QueryPath = QueryPath Text
- newtype MinimumTermFrequency = MinimumTermFrequency Int
- newtype PercentMatch = PercentMatch Double
- newtype FieldDefinition = FieldDefinition {}
- data MappingField = MappingField {}
- newtype Mapping = Mapping {}
- data UpsertActionMetadata
- buildUpsertActionMetadata :: UpsertActionMetadata -> Pair
- data UpsertPayload
- newtype AllowLeadingWildcard = AllowLeadingWildcard Bool
- newtype LowercaseExpanded = LowercaseExpanded Bool
- newtype GeneratePhraseQueries = GeneratePhraseQueries Bool
- newtype Locale = Locale Text
- newtype AnalyzeWildcard = AnalyzeWildcard Bool
- newtype EnablePositionIncrements = EnablePositionIncrements Bool
- data SimpleQueryFlag
- data FieldOrFields
- class Semigroup a => Monoid a where
- class ToJSON a where
- toJSON :: a -> Value
- toEncoding :: a -> Encoding
- toJSONList :: [a] -> Value
- toEncodingList :: [a] -> Encoding
- data Interval
- data TimeInterval
- data ExecutionHint
- data CollectionMode
- data TermOrder = TermOrder {}
- data TermInclusion
- data SnapshotRepoSelection
- data GenericSnapshotRepo = GenericSnapshotRepo {}
- class SnapshotRepo r where
- data SnapshotRepoConversionError
- newtype SnapshotRepoType = SnapshotRepoType {}
- newtype GenericSnapshotRepoSettings = GenericSnapshotRepoSettings {}
- newtype SnapshotRepoUpdateSettings = SnapshotRepoUpdateSettings {}
- defaultSnapshotRepoUpdateSettings :: SnapshotRepoUpdateSettings
- newtype SnapshotRepoName = SnapshotRepoName {}
- data SnapshotRepoPattern
- 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 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 NodeThreadPoolInfo = NodeThreadPoolInfo {}
- data ThreadPoolSize
- data ThreadPoolType
- data NodeJVMInfo = NodeJVMInfo {}
- newtype JVMMemoryPool = JVMMemoryPool {}
- newtype JVMGCCollector = JVMGCCollector {}
- data JVMMemoryInfo = JVMMemoryInfo {}
- 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 FsSnapshotRepo = FsSnapshotRepo {}
- data SnapshotCreateSettings = SnapshotCreateSettings {}
- defaultSnapshotCreateSettings :: SnapshotCreateSettings
- data SnapshotSelection
- data SnapshotPattern
- data SnapshotInfo = SnapshotInfo {}
- data SnapshotShardFailure = SnapshotShardFailure {}
- newtype ShardId = ShardId {}
- newtype SnapshotName = SnapshotName {
- snapshotName :: Text
- 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)
- defaultSnapshotRestoreSettings :: SnapshotRestoreSettings
- newtype RestoreRenamePattern = RestoreRenamePattern {}
- data RestoreRenameToken
- data RRGroupRefNum
- rrGroupRefNum :: RRGroupRefNum -> Int
- mkRRGroupRefNum :: Int -> Maybe RRGroupRefNum
- newtype RestoreIndexSettings = RestoreIndexSettings {}
- data Suggest = Suggest {}
- data SuggestType = SuggestTypePhraseSuggester PhraseSuggester
- data PhraseSuggester = PhraseSuggester {
- phraseSuggesterField :: FieldName
- phraseSuggesterGramSize :: Maybe Int
- phraseSuggesterRealWordErrorLikelihood :: Maybe Int
- phraseSuggesterConfidence :: Maybe Int
- phraseSuggesterMaxErrors :: Maybe Int
- phraseSuggesterSeparator :: Maybe Text
- phraseSuggesterSize :: Maybe Size
- phraseSuggesterAnalyzer :: Maybe Analyzer
- phraseSuggesterShardSize :: Maybe Int
- phraseSuggesterHighlight :: Maybe PhraseSuggesterHighlighter
- phraseSuggesterCollate :: Maybe PhraseSuggesterCollate
- phraseSuggesterCandidateGenerators :: [DirectGenerators]
- data PhraseSuggesterHighlighter = PhraseSuggesterHighlighter {}
- data PhraseSuggesterCollate = PhraseSuggesterCollate {}
- mkPhraseSuggester :: FieldName -> PhraseSuggester
- data SuggestOptions = SuggestOptions {}
- data SuggestResponse = SuggestResponse {}
- data NamedSuggestionResponse = NamedSuggestionResponse {
- nsrName :: Text
- nsrResponses :: [SuggestResponse]
- data DirectGenerators = DirectGenerators {
- directGeneratorsField :: FieldName
- directGeneratorsSize :: Maybe Int
- directGeneratorSuggestMode :: DirectGeneratorSuggestModeTypes
- directGeneratorMaxEdits :: Maybe Double
- directGeneratorPrefixLength :: Maybe Int
- directGeneratorMinWordLength :: Maybe Int
- directGeneratorMaxInspections :: Maybe Int
- directGeneratorMinDocFreq :: Maybe Double
- directGeneratorMaxTermFreq :: Maybe Double
- directGeneratorPreFilter :: Maybe Text
- directGeneratorPostFilter :: Maybe Text
- mkDirectGenerators :: FieldName -> DirectGenerators
- data DirectGeneratorSuggestModeTypes
- data Aggregation
- = TermsAgg TermsAggregation
- | CardinalityAgg CardinalityAggregation
- | DateHistogramAgg DateHistogramAggregation
- | ValueCountAgg ValueCountAggregation
- | FilterAgg FilterAggregation
- | DateRangeAgg DateRangeAggregation
- | MissingAgg MissingAggregation
- | TopHitsAgg TopHitsAggregation
- | StatsAgg StatisticsAggregation
- type Aggregations = Map Key Aggregation
- type AggregationResults = Map Key Value
- data BucketValue
- data Bucket a = Bucket {
- buckets :: [a]
- class BucketAggregation a where
- key :: a -> BucketValue
- docCount :: a -> Int
- aggs :: a -> Maybe AggregationResults
- data TermsAggregation = TermsAggregation {
- term :: Either Text Text
- termInclude :: Maybe TermInclusion
- termExclude :: Maybe TermInclusion
- termOrder :: Maybe TermOrder
- termMinDocCount :: Maybe Int
- termSize :: Maybe Int
- termShardSize :: Maybe Int
- termCollectMode :: Maybe CollectionMode
- termExecutionHint :: Maybe ExecutionHint
- termAggs :: Maybe Aggregations
- data MissingAggregation = MissingAggregation {}
- data ValueCountAggregation
- data FilterAggregation = FilterAggregation {}
- data CardinalityAggregation = CardinalityAggregation {}
- data DateHistogramAggregation = DateHistogramAggregation {}
- data DateRangeAggregation = DateRangeAggregation {}
- data DateRangeAggRange
- data DateMathExpr = DateMathExpr DateMathAnchor [DateMathModifier]
- data DateMathAnchor
- data DateMathModifier
- data DateMathUnit
- data TopHitsAggregation = TopHitsAggregation {}
- data StatisticsAggregation = StatisticsAggregation {}
- type SearchAfterKey = [Value]
- newtype CountQuery = CountQuery {
- countQuery :: Query
- data CountResponse = CountResponse {}
- data CountShards = CountShards {}
- data Highlights = Highlights {}
- data FieldHighlight = FieldHighlight FieldName (Maybe HighlightSettings)
- data HighlightSettings
- data PlainHighlight = PlainHighlight {}
- data PostingsHighlight = PostingsHighlight (Maybe CommonHighlight)
- data FastVectorHighlight = FastVectorHighlight {}
- data CommonHighlight = CommonHighlight {}
- data NonPostings = NonPostings {}
- data HighlightEncoder
- data HighlightTag
- = TagSchema Text
- | CustomTags ([Text], [Text])
- type HitHighlight = Map Text [Text]
- data MissingResult = MissingResult {}
- data TermsResult = TermsResult {}
- data DateHistogramResult = DateHistogramResult {}
- data DateRangeResult = DateRangeResult {}
- data TopHitResult a = TopHitResult {
- tarHits :: SearchHits a
- newtype EsUsername = EsUsername {
- esUsername :: Text
- newtype EsPassword = EsPassword {
- esPassword :: Text
- data Analysis = Analysis {}
- data AnalyzerDefinition = AnalyzerDefinition {}
- newtype TokenizerDefinition = TokenizerDefinitionNgram Ngram
- data TokenFilterDefinition
- = TokenFilterDefinitionLowercase (Maybe Language)
- | TokenFilterDefinitionUppercase (Maybe Language)
- | TokenFilterDefinitionApostrophe
- | TokenFilterDefinitionReverse
- | TokenFilterDefinitionSnowball Language
- | TokenFilterDefinitionShingle Shingle
- | TokenFilterDefinitionStemmer Language
- | TokenFilterDefinitionStop (Either Language [StopWord])
- data CharFilterDefinition
- data Ngram = Ngram {
- ngramMinGram :: Int
- ngramMaxGram :: Int
- ngramTokenChars :: [TokenChar]
- data TokenChar
- data Shingle = Shingle {}
- data Language
- = Arabic
- | Armenian
- | Basque
- | Bengali
- | Brazilian
- | Bulgarian
- | Catalan
- | Cjk
- | Czech
- | Danish
- | Dutch
- | English
- | Finnish
- | French
- | Galician
- | German
- | German2
- | Greek
- | Hindi
- | Hungarian
- | Indonesian
- | Irish
- | Italian
- | Kp
- | Latvian
- | Lithuanian
- | Lovins
- | Norwegian
- | Persian
- | Porter
- | Portuguese
- | Romanian
- | Russian
- | Sorani
- | Spanish
- | Swedish
- | Thai
- | Turkish
Documentation
defaultCache :: Cache Source #
defaultIndexSettings :: IndexSettings Source #
defaultIndexSettings is an IndexSettings with 3 shards and
2 replicas.
defaultIndexDocumentSettings :: IndexDocumentSettings Source #
Reasonable default settings. Chooses no version control and no parent.
mkMatchQuery :: FieldName -> QueryString -> MatchQuery Source #
mkMatchQuery is a convenience function that defaults the less common parameters,
enabling you to provide only the FieldName and QueryString to make a MatchQuery
mkMultiMatchQuery :: [FieldName] -> QueryString -> MultiMatchQuery Source #
mkMultiMatchQuery is a convenience function that defaults the less common parameters,
enabling you to provide only the list of FieldNames and QueryString to
make a MultiMatchQuery.
mkRangeQuery :: FieldName -> RangeValue -> RangeQuery Source #
mkAggregations :: Key -> Aggregation -> Aggregations Source #
mkDocVersion :: Int -> Maybe DocVersion Source #
Smart constructor for in-range doc version
docVersionNumber :: DocVersion -> Int Source #
toMissing :: Key -> AggregationResults -> Maybe MissingResult Source #
toTerms :: Key -> AggregationResults -> Maybe (Bucket TermsResult) Source #
toTopHits :: FromJSON a => Key -> AggregationResults -> Maybe (TopHitResult a) Source #
Instances
Common environment for Elasticsearch calls. Connections will be pipelined according to the provided HTTP connection manager.
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 }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.
Constructors
| Version | |
Fields | |
newtype VersionNumber Source #
Traditional software versioning number
Constructors
| VersionNumber | |
Fields | |
Instances
Typically a 7 character hex string.
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 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 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] # | |
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] # | |
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 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 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 | |
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] # | |
A measure of bytes used for various configurations. You may want
to use smart constructors like gigabytes for larger values.
>>>gigabytes 9Bytes 9000000000
>>>megabytes 9Bytes 9000000
>>>kilobytes 9Bytes 9000
Constructors
| FSSimple | |
| FSBuffered |
data InitialShardCount Source #
Instances
| 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] # | |
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 # | |
Server is used with the client functions to point at the ES instance
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 # | |
newtype IndexAliasName Source #
Constructors
| IndexAliasName | |
Fields | |
Instances
| Eq IndexAliasName Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: IndexAliasName -> IndexAliasName -> Bool # (/=) :: IndexAliasName -> IndexAliasName -> Bool # | |
| Show IndexAliasName Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> IndexAliasName -> ShowS # show :: IndexAliasName -> String # showList :: [IndexAliasName] -> ShowS # | |
| ToJSON IndexAliasName Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: IndexAliasName -> Value # toEncoding :: IndexAliasName -> Encoding # toJSONList :: [IndexAliasName] -> Value # toEncodingList :: [IndexAliasName] -> 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 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 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 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 | |
data DocVersion Source #
DocVersion is an integer version number for a document between 1
and 9.2e+18 used for .
Instances
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 # | |
Constructors
Constructors
| Search | |
Fields
| |
data SearchType Source #
Constructors
| SearchTypeQueryThenFetch | |
| SearchTypeDfsQueryThenFetch |
Instances
| Eq SearchType Source # | |
Defined in Database.Bloodhound.Types | |
| Show SearchType Source # | |
Defined in Database.Bloodhound.Types Methods showsPrec :: Int -> SearchType -> ShowS # show :: SearchType -> String # showList :: [SearchType] -> ShowS # | |
| ToJSON SearchType Source # | |
Defined in Database.Bloodhound.Types Methods toJSON :: SearchType -> Value # toEncoding :: SearchType -> Encoding # toJSONList :: [SearchType] -> Value # toEncodingList :: [SearchType] -> Encoding # | |
| FromJSON SearchType Source # | |
Defined in Database.Bloodhound.Types | |
data SearchResult a Source #
Constructors
| SearchResult | |
Fields
| |
Instances
| Eq a => Eq (SearchResult a) Source # | |
Defined in Database.Bloodhound.Types Methods (==) :: SearchResult a -> SearchResult a -> Bool # (/=) :: SearchResult a -> SearchResult a -> Bool # | |
| Show a => Show (SearchResult a) Source # | |
Defined in Database.Bloodhound.Types Methods showsPrec :: Int -> SearchResult a -> ShowS # show :: SearchResult a -> String # showList :: [SearchResult a] -> ShowS # | |
| FromJSON a => FromJSON (SearchResult a) Source # | |
Defined in Database.Bloodhound.Types Methods parseJSON :: Value -> Parser (SearchResult a) # parseJSONList :: Value -> Parser [SearchResult a] # | |
data HitsTotalRelation Source #
Instances
| Eq HitsTotalRelation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: HitsTotalRelation -> HitsTotalRelation -> Bool # (/=) :: HitsTotalRelation -> HitsTotalRelation -> Bool # | |
| Show HitsTotalRelation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> HitsTotalRelation -> ShowS # show :: HitsTotalRelation -> String # showList :: [HitsTotalRelation] -> ShowS # | |
| FromJSON HitsTotalRelation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods parseJSON :: Value -> Parser HitsTotalRelation # parseJSONList :: Value -> Parser [HitsTotalRelation] # | |
Constructors
| HitsTotal | |
Fields
| |
data SearchHits a Source #
Instances
| Eq a => Eq (SearchHits a) Source # | |
Defined in Database.Bloodhound.Internal.Aggregation | |
| Show a => Show (SearchHits a) Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> SearchHits a -> ShowS # show :: SearchHits a -> String # showList :: [SearchHits a] -> ShowS # | |
| Semigroup (SearchHits a) Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (<>) :: SearchHits a -> SearchHits a -> SearchHits a # sconcat :: NonEmpty (SearchHits a) -> SearchHits a # stimes :: Integral b => b -> SearchHits a -> SearchHits a # | |
| Monoid (SearchHits a) Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods mempty :: SearchHits a # mappend :: SearchHits a -> SearchHits a -> SearchHits a # mconcat :: [SearchHits a] -> SearchHits a # | |
| FromJSON a => FromJSON (SearchHits a) Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods parseJSON :: Value -> Parser (SearchHits a) # parseJSONList :: Value -> Parser [SearchHits a] # | |
type TrackSortScores = Bool Source #
data PatternOrPatterns Source #
Constructors
| PopPattern Pattern | |
| PopPatterns [Pattern] |
Instances
| Eq PatternOrPatterns Source # | |
Defined in Database.Bloodhound.Types Methods (==) :: PatternOrPatterns -> PatternOrPatterns -> Bool # (/=) :: PatternOrPatterns -> PatternOrPatterns -> Bool # | |
| Read PatternOrPatterns Source # | |
Defined in Database.Bloodhound.Types Methods readsPrec :: Int -> ReadS PatternOrPatterns # readList :: ReadS [PatternOrPatterns] # | |
| Show PatternOrPatterns Source # | |
Defined in Database.Bloodhound.Types Methods showsPrec :: Int -> PatternOrPatterns -> ShowS # show :: PatternOrPatterns -> String # showList :: [PatternOrPatterns] -> ShowS # | |
| ToJSON PatternOrPatterns Source # | |
Defined in Database.Bloodhound.Types Methods toJSON :: PatternOrPatterns -> Value # toEncoding :: PatternOrPatterns -> Encoding # toJSONList :: [PatternOrPatterns] -> Value # toEncodingList :: [PatternOrPatterns] -> Encoding # | |
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 | |
Constructors
| Hit | |
Fields
| |
As of Elastic 2.0, Filters are just Queries housed in a
Bool Query, and flagged in a different context.
Constructors
| MustMatch Term Cache | |
| MustNotMatch Term Cache | |
| ShouldMatch [Term] Cache |
data GeoBoundingBoxConstraint Source #
Constructors
| GeoBoundingBoxConstraint | |
Fields | |
Instances
| Eq GeoBoundingBoxConstraint Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: GeoBoundingBoxConstraint -> GeoBoundingBoxConstraint -> Bool # (/=) :: GeoBoundingBoxConstraint -> GeoBoundingBoxConstraint -> Bool # | |
| Show GeoBoundingBoxConstraint Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> GeoBoundingBoxConstraint -> ShowS # show :: GeoBoundingBoxConstraint -> String # showList :: [GeoBoundingBoxConstraint] -> ShowS # | |
| ToJSON GeoBoundingBoxConstraint Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: GeoBoundingBoxConstraint -> Value # toEncoding :: GeoBoundingBoxConstraint -> Encoding # toJSONList :: [GeoBoundingBoxConstraint] -> Value # | |
| FromJSON GeoBoundingBoxConstraint Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser GeoBoundingBoxConstraint # parseJSONList :: Value -> Parser [GeoBoundingBoxConstraint] # | |
data GeoBoundingBox Source #
Constructors
| GeoBoundingBox | |
Fields
| |
Instances
| Eq GeoBoundingBox Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: GeoBoundingBox -> GeoBoundingBox -> Bool # (/=) :: GeoBoundingBox -> GeoBoundingBox -> Bool # | |
| Show GeoBoundingBox Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> GeoBoundingBox -> ShowS # show :: GeoBoundingBox -> String # showList :: [GeoBoundingBox] -> ShowS # | |
| ToJSON GeoBoundingBox Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: GeoBoundingBox -> Value # toEncoding :: GeoBoundingBox -> Encoding # toJSONList :: [GeoBoundingBox] -> Value # toEncodingList :: [GeoBoundingBox] -> Encoding # | |
| FromJSON GeoBoundingBox Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser GeoBoundingBox # parseJSONList :: Value -> Parser [GeoBoundingBox] # | |
data GeoFilterType Source #
Constructors
| GeoFilterMemory | |
| GeoFilterIndexed |
Instances
| Eq GeoFilterType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: GeoFilterType -> GeoFilterType -> Bool # (/=) :: GeoFilterType -> GeoFilterType -> Bool # | |
| Show GeoFilterType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> GeoFilterType -> ShowS # show :: GeoFilterType -> String # showList :: [GeoFilterType] -> ShowS # | |
| ToJSON GeoFilterType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: GeoFilterType -> Value # toEncoding :: GeoFilterType -> Encoding # toJSONList :: [GeoFilterType] -> Value # toEncodingList :: [GeoFilterType] -> Encoding # | |
| FromJSON GeoFilterType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser GeoFilterType # parseJSONList :: Value -> Parser [GeoFilterType] # | |
Constructors
| Distance | |
Fields
| |
data DistanceUnit Source #
Constructors
| Miles | |
| Yards | |
| Feet | |
| Inches | |
| Kilometers | |
| Meters | |
| Centimeters | |
| Millimeters | |
| NauticalMiles |
Instances
| Eq DistanceUnit Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show DistanceUnit Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> DistanceUnit -> ShowS # show :: DistanceUnit -> String # showList :: [DistanceUnit] -> ShowS # | |
| ToJSON DistanceUnit Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: DistanceUnit -> Value # toEncoding :: DistanceUnit -> Encoding # toJSONList :: [DistanceUnit] -> Value # toEncodingList :: [DistanceUnit] -> Encoding # | |
| FromJSON DistanceUnit Source # | |
Defined in Database.Bloodhound.Internal.Query | |
data DistanceType Source #
Instances
| Eq DistanceType Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show DistanceType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> DistanceType -> ShowS # show :: DistanceType -> String # showList :: [DistanceType] -> ShowS # | |
| ToJSON DistanceType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: DistanceType -> Value # toEncoding :: DistanceType -> Encoding # toJSONList :: [DistanceType] -> Value # toEncodingList :: [DistanceType] -> Encoding # | |
| FromJSON DistanceType Source # | |
Defined in Database.Bloodhound.Internal.Query | |
data DistanceRange Source #
Constructors
| DistanceRange | |
Fields | |
Instances
| Eq DistanceRange Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: DistanceRange -> DistanceRange -> Bool # (/=) :: DistanceRange -> DistanceRange -> Bool # | |
| Show DistanceRange Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> DistanceRange -> ShowS # show :: DistanceRange -> String # showList :: [DistanceRange] -> ShowS # | |
data OptimizeBbox Source #
Constructors
| OptimizeGeoFilterType GeoFilterType | |
| NoOptimizeBbox |
Instances
| Eq OptimizeBbox Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show OptimizeBbox Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> OptimizeBbox -> ShowS # show :: OptimizeBbox -> String # showList :: [OptimizeBbox] -> ShowS # | |
| ToJSON OptimizeBbox Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: OptimizeBbox -> Value # toEncoding :: OptimizeBbox -> Encoding # toJSONList :: [OptimizeBbox] -> Value # toEncodingList :: [OptimizeBbox] -> Encoding # | |
| FromJSON OptimizeBbox Source # | |
Defined in Database.Bloodhound.Internal.Query | |
data RangeValue Source #
Constructors
Instances
| Eq RangeValue Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show RangeValue Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> RangeValue -> ShowS # show :: RangeValue -> String # showList :: [RangeValue] -> ShowS # | |
| FromJSON RangeValue Source # | |
Defined in Database.Bloodhound.Internal.Query | |
data RangeExecution Source #
Constructors
| RangeExecutionIndex | |
| RangeExecutionFielddata |
Instances
| Eq RangeExecution Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: RangeExecution -> RangeExecution -> Bool # (/=) :: RangeExecution -> RangeExecution -> Bool # | |
| Show RangeExecution Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> RangeExecution -> ShowS # show :: RangeExecution -> String # showList :: [RangeExecution] -> ShowS # | |
| ToJSON RangeExecution Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: RangeExecution -> Value # toEncoding :: RangeExecution -> Encoding # toJSONList :: [RangeExecution] -> Value # toEncodingList :: [RangeExecution] -> Encoding # | |
| FromJSON RangeExecution Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser RangeExecution # parseJSONList :: Value -> Parser [RangeExecution] # | |
newtype LessThanEq Source #
Constructors
| LessThanEq Double |
Instances
| Eq LessThanEq Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show LessThanEq Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> LessThanEq -> ShowS # show :: LessThanEq -> String # showList :: [LessThanEq] -> ShowS # | |
newtype GreaterThan Source #
Constructors
| GreaterThan Double |
Instances
| Eq GreaterThan Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show GreaterThan Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> GreaterThan -> ShowS # show :: GreaterThan -> String # showList :: [GreaterThan] -> ShowS # | |
newtype GreaterThanEq Source #
Constructors
| GreaterThanEq Double |
Instances
| Eq GreaterThanEq Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: GreaterThanEq -> GreaterThanEq -> Bool # (/=) :: GreaterThanEq -> GreaterThanEq -> Bool # | |
| Show GreaterThanEq Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> GreaterThanEq -> ShowS # show :: GreaterThanEq -> String # showList :: [GreaterThanEq] -> ShowS # | |
newtype LessThanEqD Source #
Constructors
| LessThanEqD UTCTime |
Instances
| Eq LessThanEqD Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show LessThanEqD Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> LessThanEqD -> ShowS # show :: LessThanEqD -> String # showList :: [LessThanEqD] -> ShowS # | |
newtype GreaterThanD Source #
Constructors
| GreaterThanD UTCTime |
Instances
| Eq GreaterThanD Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show GreaterThanD Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> GreaterThanD -> ShowS # show :: GreaterThanD -> String # showList :: [GreaterThanD] -> ShowS # | |
newtype GreaterThanEqD Source #
Constructors
| GreaterThanEqD UTCTime |
Instances
| Eq GreaterThanEqD Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: GreaterThanEqD -> GreaterThanEqD -> Bool # (/=) :: GreaterThanEqD -> GreaterThanEqD -> Bool # | |
| Show GreaterThanEqD Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> GreaterThanEqD -> ShowS # show :: GreaterThanEqD -> String # showList :: [GreaterThanEqD] -> ShowS # | |
data RegexpFlags Source #
Constructors
| AllRegexpFlags | |
| NoRegexpFlags | |
| SomeRegexpFlags (NonEmpty RegexpFlag) |
Instances
| Eq RegexpFlags Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show RegexpFlags Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> RegexpFlags -> ShowS # show :: RegexpFlags -> String # showList :: [RegexpFlags] -> ShowS # | |
| ToJSON RegexpFlags Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: RegexpFlags -> Value # toEncoding :: RegexpFlags -> Encoding # toJSONList :: [RegexpFlags] -> Value # toEncodingList :: [RegexpFlags] -> Encoding # | |
| FromJSON RegexpFlags Source # | |
Defined in Database.Bloodhound.Internal.Query | |
data RegexpFlag Source #
Constructors
| AnyString | |
| Automaton | |
| Complement | |
| Empty | |
| Intersection | |
| Interval |
Instances
| Eq RegexpFlag Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show RegexpFlag Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> RegexpFlag -> ShowS # show :: RegexpFlag -> String # showList :: [RegexpFlag] -> ShowS # | |
| FromJSON RegexpFlag Source # | |
Defined in Database.Bloodhound.Internal.Query | |
FieldName is used all over the place wherever a specific field within
a document needs to be specified, usually in Querys or Filters.
newtype ScriptFields Source #
Constructors
| ScriptFields (KeyMap ScriptFieldValue) |
Instances
| Eq ScriptFields Source # | |
Defined in Database.Bloodhound.Common.Script | |
| Show ScriptFields Source # | |
Defined in Database.Bloodhound.Common.Script Methods showsPrec :: Int -> ScriptFields -> ShowS # show :: ScriptFields -> String # showList :: [ScriptFields] -> ShowS # | |
| ToJSON ScriptFields Source # | |
Defined in Database.Bloodhound.Common.Script Methods toJSON :: ScriptFields -> Value # toEncoding :: ScriptFields -> Encoding # toJSONList :: [ScriptFields] -> Value # toEncodingList :: [ScriptFields] -> Encoding # | |
| FromJSON ScriptFields Source # | |
Defined in Database.Bloodhound.Common.Script | |
type ScriptFieldValue = Value Source #
Constructors
| Script | |
Fields | |
newtype ScriptLanguage Source #
Constructors
| ScriptLanguage Text |
Instances
| Eq ScriptLanguage Source # | |
Defined in Database.Bloodhound.Common.Script Methods (==) :: ScriptLanguage -> ScriptLanguage -> Bool # (/=) :: ScriptLanguage -> ScriptLanguage -> Bool # | |
| Show ScriptLanguage Source # | |
Defined in Database.Bloodhound.Common.Script Methods showsPrec :: Int -> ScriptLanguage -> ShowS # show :: ScriptLanguage -> String # showList :: [ScriptLanguage] -> ShowS # | |
| ToJSON ScriptLanguage Source # | |
Defined in Database.Bloodhound.Common.Script Methods toJSON :: ScriptLanguage -> Value # toEncoding :: ScriptLanguage -> Encoding # toJSONList :: [ScriptLanguage] -> Value # toEncodingList :: [ScriptLanguage] -> Encoding # | |
| FromJSON ScriptLanguage Source # | |
Defined in Database.Bloodhound.Common.Script Methods parseJSON :: Value -> Parser ScriptLanguage # parseJSONList :: Value -> Parser [ScriptLanguage] # | |
data ScriptSource Source #
Constructors
| ScriptId Text | |
| ScriptInline Text |
Instances
| Eq ScriptSource Source # | |
Defined in Database.Bloodhound.Common.Script | |
| Show ScriptSource Source # | |
Defined in Database.Bloodhound.Common.Script Methods showsPrec :: Int -> ScriptSource -> ShowS # show :: ScriptSource -> String # showList :: [ScriptSource] -> ShowS # | |
newtype ScriptParams Source #
Constructors
| ScriptParams (KeyMap ScriptParamValue) |
Instances
| Eq ScriptParams Source # | |
Defined in Database.Bloodhound.Common.Script | |
| Show ScriptParams Source # | |
Defined in Database.Bloodhound.Common.Script Methods showsPrec :: Int -> ScriptParams -> ShowS # show :: ScriptParams -> String # showList :: [ScriptParams] -> ShowS # | |
| ToJSON ScriptParams Source # | |
Defined in Database.Bloodhound.Common.Script Methods toJSON :: ScriptParams -> Value # toEncoding :: ScriptParams -> Encoding # toJSONList :: [ScriptParams] -> Value # toEncodingList :: [ScriptParams] -> Encoding # | |
| FromJSON ScriptParams Source # | |
Defined in Database.Bloodhound.Common.Script | |
type ScriptParamValue = Value Source #
IndexName is used to describe which index to querycreatedelete
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 # | |
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.
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 | |
DocId is a generic wrapper value for expressing unique Document IDs.
Can be set by the user or created by ES itself. Often used in client
functions for poking at specific documents.
CacheKey is used in RegexpFilter to key regex caching.
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 # | |
newtype ReplicaCount Source #
ReplicaCount is part of IndexSettings
Constructors
| ReplicaCount Int |
Instances
| Eq ReplicaCount Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show ReplicaCount Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> ReplicaCount -> ShowS # show :: ReplicaCount -> String # showList :: [ReplicaCount] -> ShowS # | |
| ToJSON ReplicaCount Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: ReplicaCount -> Value # toEncoding :: ReplicaCount -> Encoding # toJSONList :: [ReplicaCount] -> Value # toEncodingList :: [ReplicaCount] -> Encoding # | |
| FromJSON ReplicaCount Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
newtype ShardCount Source #
ShardCount is part of IndexSettings
Constructors
| ShardCount Int |
Instances
| Eq ShardCount Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show ShardCount Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> ShardCount -> ShowS # show :: ShardCount -> String # showList :: [ShardCount] -> ShowS # | |
| ToJSON ShardCount Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: ShardCount -> Value # toEncoding :: ShardCount -> Encoding # toJSONList :: [ShardCount] -> Value # toEncodingList :: [ShardCount] -> Encoding # | |
| FromJSON ShardCount Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
SortMode prescribes how to handle sorting array/multi-valued fields.
SortOrder is Ascending or Descending, as you might expect. These get
encoded into "asc" or "desc" when turned into JSON.
Constructors
| Ascending | |
| Descending |
The two main kinds of SortSpec are DefaultSortSpec and
GeoDistanceSortSpec. The latter takes a SortOrder, GeoPoint, and
DistanceUnit to express "nearness" to a single geographical point as a
sort specification.
data DefaultSort Source #
DefaultSort is usually the kind of SortSpec you'll want. There's a
mkSort convenience function for when you want to specify only the most
common parameters.
The ignoreUnmapped, when Just field is used to set the elastic unmapped_type
Constructors
| DefaultSort | |
Fields
| |
Instances
| Eq DefaultSort Source # | |
Defined in Database.Bloodhound.Internal.Sort | |
| Show DefaultSort Source # | |
Defined in Database.Bloodhound.Internal.Sort Methods showsPrec :: Int -> DefaultSort -> ShowS # show :: DefaultSort -> String # showList :: [DefaultSort] -> ShowS # | |
Missing prescribes how to handle missing fields. A missing field can be
sorted last, first, or using a custom value as a substitute.
Constructors
| LastMissing | |
| FirstMissing | |
| CustomMissing Text |
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 # | |
data MatchQuery Source #
Constructors
Instances
| Eq MatchQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show MatchQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> MatchQuery -> ShowS # show :: MatchQuery -> String # showList :: [MatchQuery] -> ShowS # | |
| ToJSON MatchQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: MatchQuery -> Value # toEncoding :: MatchQuery -> Encoding # toJSONList :: [MatchQuery] -> Value # toEncodingList :: [MatchQuery] -> Encoding # | |
| FromJSON MatchQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
data MultiMatchQuery Source #
Constructors
Instances
| Eq MultiMatchQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: MultiMatchQuery -> MultiMatchQuery -> Bool # (/=) :: MultiMatchQuery -> MultiMatchQuery -> Bool # | |
| Show MultiMatchQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> MultiMatchQuery -> ShowS # show :: MultiMatchQuery -> String # showList :: [MultiMatchQuery] -> ShowS # | |
| ToJSON MultiMatchQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: MultiMatchQuery -> Value # toEncoding :: MultiMatchQuery -> Encoding # toJSONList :: [MultiMatchQuery] -> Value # toEncodingList :: [MultiMatchQuery] -> Encoding # | |
| FromJSON MultiMatchQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser MultiMatchQuery # parseJSONList :: Value -> Parser [MultiMatchQuery] # | |
Constructors
| BoolQuery | |
Fields | |
data BoostingQuery Source #
Constructors
| BoostingQuery | |
Fields
| |
Instances
| Eq BoostingQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: BoostingQuery -> BoostingQuery -> Bool # (/=) :: BoostingQuery -> BoostingQuery -> Bool # | |
| Show BoostingQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> BoostingQuery -> ShowS # show :: BoostingQuery -> String # showList :: [BoostingQuery] -> ShowS # | |
| ToJSON BoostingQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: BoostingQuery -> Value # toEncoding :: BoostingQuery -> Encoding # toJSONList :: [BoostingQuery] -> Value # toEncodingList :: [BoostingQuery] -> Encoding # | |
| FromJSON BoostingQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser BoostingQuery # parseJSONList :: Value -> Parser [BoostingQuery] # | |
data CommonTermsQuery Source #
Constructors
Instances
| Eq CommonTermsQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: CommonTermsQuery -> CommonTermsQuery -> Bool # (/=) :: CommonTermsQuery -> CommonTermsQuery -> Bool # | |
| Show CommonTermsQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> CommonTermsQuery -> ShowS # show :: CommonTermsQuery -> String # showList :: [CommonTermsQuery] -> ShowS # | |
| ToJSON CommonTermsQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: CommonTermsQuery -> Value # toEncoding :: CommonTermsQuery -> Encoding # toJSONList :: [CommonTermsQuery] -> Value # toEncodingList :: [CommonTermsQuery] -> Encoding # | |
| FromJSON CommonTermsQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser CommonTermsQuery # parseJSONList :: Value -> Parser [CommonTermsQuery] # | |
data FunctionScoreQuery Source #
Constructors
| FunctionScoreQuery | |
Instances
| Eq FunctionScoreQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: FunctionScoreQuery -> FunctionScoreQuery -> Bool # (/=) :: FunctionScoreQuery -> FunctionScoreQuery -> Bool # | |
| Show FunctionScoreQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> FunctionScoreQuery -> ShowS # show :: FunctionScoreQuery -> String # showList :: [FunctionScoreQuery] -> ShowS # | |
| ToJSON FunctionScoreQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: FunctionScoreQuery -> Value # toEncoding :: FunctionScoreQuery -> Encoding # toJSONList :: [FunctionScoreQuery] -> Value # toEncodingList :: [FunctionScoreQuery] -> Encoding # | |
| FromJSON FunctionScoreQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser FunctionScoreQuery # parseJSONList :: Value -> Parser [FunctionScoreQuery] # | |
data FunctionScoreFunctions Source #
Constructors
| FunctionScoreSingle FunctionScoreFunction | |
| FunctionScoreMultiple (NonEmpty ComponentFunctionScoreFunction) |
Instances
| Eq FunctionScoreFunctions Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: FunctionScoreFunctions -> FunctionScoreFunctions -> Bool # (/=) :: FunctionScoreFunctions -> FunctionScoreFunctions -> Bool # | |
| Show FunctionScoreFunctions Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> FunctionScoreFunctions -> ShowS # show :: FunctionScoreFunctions -> String # showList :: [FunctionScoreFunctions] -> ShowS # | |
data ComponentFunctionScoreFunction Source #
Constructors
| ComponentFunctionScoreFunction | |
Instances
data FunctionScoreFunction Source #
Constructors
| FunctionScoreFunctionScript Script | |
| FunctionScoreFunctionRandom Seed | |
| FunctionScoreFunctionFieldValueFactor FieldValueFactor |
Instances
| Eq FunctionScoreFunction Source # | |
Defined in Database.Bloodhound.Common.Script Methods (==) :: FunctionScoreFunction -> FunctionScoreFunction -> Bool # (/=) :: FunctionScoreFunction -> FunctionScoreFunction -> Bool # | |
| Show FunctionScoreFunction Source # | |
Defined in Database.Bloodhound.Common.Script Methods showsPrec :: Int -> FunctionScoreFunction -> ShowS # show :: FunctionScoreFunction -> String # showList :: [FunctionScoreFunction] -> ShowS # | |
data FieldValueFactor Source #
Constructors
| FieldValueFactor | |
Instances
| Eq FieldValueFactor Source # | |
Defined in Database.Bloodhound.Common.Script Methods (==) :: FieldValueFactor -> FieldValueFactor -> Bool # (/=) :: FieldValueFactor -> FieldValueFactor -> Bool # | |
| Show FieldValueFactor Source # | |
Defined in Database.Bloodhound.Common.Script Methods showsPrec :: Int -> FieldValueFactor -> ShowS # show :: FieldValueFactor -> String # showList :: [FieldValueFactor] -> ShowS # | |
| ToJSON FieldValueFactor Source # | |
Defined in Database.Bloodhound.Common.Script Methods toJSON :: FieldValueFactor -> Value # toEncoding :: FieldValueFactor -> Encoding # toJSONList :: [FieldValueFactor] -> Value # toEncodingList :: [FieldValueFactor] -> Encoding # | |
| FromJSON FieldValueFactor Source # | |
Defined in Database.Bloodhound.Common.Script Methods parseJSON :: Value -> Parser FieldValueFactor # parseJSONList :: Value -> Parser [FieldValueFactor] # | |
data FactorModifier Source #
Constructors
| FactorModifierNone | |
| FactorModifierLog | |
| FactorModifierLog1p | |
| FactorModifierLog2p | |
| FactorModifierLn | |
| FactorModifierLn1p | |
| FactorModifierLn2p | |
| FactorModifierSquare | |
| FactorModifierSqrt | |
| FactorModifierReciprocal |
Instances
| Eq FactorModifier Source # | |
Defined in Database.Bloodhound.Common.Script Methods (==) :: FactorModifier -> FactorModifier -> Bool # (/=) :: FactorModifier -> FactorModifier -> Bool # | |
| Show FactorModifier Source # | |
Defined in Database.Bloodhound.Common.Script Methods showsPrec :: Int -> FactorModifier -> ShowS # show :: FactorModifier -> String # showList :: [FactorModifier] -> ShowS # | |
| ToJSON FactorModifier Source # | |
Defined in Database.Bloodhound.Common.Script Methods toJSON :: FactorModifier -> Value # toEncoding :: FactorModifier -> Encoding # toJSONList :: [FactorModifier] -> Value # toEncodingList :: [FactorModifier] -> Encoding # | |
| FromJSON FactorModifier Source # | |
Defined in Database.Bloodhound.Common.Script Methods parseJSON :: Value -> Parser FactorModifier # parseJSONList :: Value -> Parser [FactorModifier] # | |
newtype FactorMissingFieldValue Source #
Constructors
| FactorMissingFieldValue Float |
Instances
| Eq FactorMissingFieldValue Source # | |
Defined in Database.Bloodhound.Common.Script Methods (==) :: FactorMissingFieldValue -> FactorMissingFieldValue -> Bool # (/=) :: FactorMissingFieldValue -> FactorMissingFieldValue -> Bool # | |
| Show FactorMissingFieldValue Source # | |
Defined in Database.Bloodhound.Common.Script Methods showsPrec :: Int -> FactorMissingFieldValue -> ShowS # show :: FactorMissingFieldValue -> String # showList :: [FactorMissingFieldValue] -> ShowS # | |
| ToJSON FactorMissingFieldValue Source # | |
Defined in Database.Bloodhound.Common.Script Methods toJSON :: FactorMissingFieldValue -> Value # toEncoding :: FactorMissingFieldValue -> Encoding # toJSONList :: [FactorMissingFieldValue] -> Value # | |
| FromJSON FactorMissingFieldValue Source # | |
Defined in Database.Bloodhound.Common.Script Methods parseJSON :: Value -> Parser FactorMissingFieldValue # parseJSONList :: Value -> Parser [FactorMissingFieldValue] # | |
data DisMaxQuery Source #
Constructors
| DisMaxQuery | |
Fields
| |
Instances
| Eq DisMaxQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show DisMaxQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> DisMaxQuery -> ShowS # show :: DisMaxQuery -> String # showList :: [DisMaxQuery] -> ShowS # | |
| ToJSON DisMaxQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: DisMaxQuery -> Value # toEncoding :: DisMaxQuery -> Encoding # toJSONList :: [DisMaxQuery] -> Value # toEncodingList :: [DisMaxQuery] -> Encoding # | |
| FromJSON DisMaxQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
data FuzzyLikeThisQuery Source #
Constructors
| FuzzyLikeThisQuery | |
Instances
| Eq FuzzyLikeThisQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: FuzzyLikeThisQuery -> FuzzyLikeThisQuery -> Bool # (/=) :: FuzzyLikeThisQuery -> FuzzyLikeThisQuery -> Bool # | |
| Show FuzzyLikeThisQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> FuzzyLikeThisQuery -> ShowS # show :: FuzzyLikeThisQuery -> String # showList :: [FuzzyLikeThisQuery] -> ShowS # | |
| ToJSON FuzzyLikeThisQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: FuzzyLikeThisQuery -> Value # toEncoding :: FuzzyLikeThisQuery -> Encoding # toJSONList :: [FuzzyLikeThisQuery] -> Value # toEncodingList :: [FuzzyLikeThisQuery] -> Encoding # | |
| FromJSON FuzzyLikeThisQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser FuzzyLikeThisQuery # parseJSONList :: Value -> Parser [FuzzyLikeThisQuery] # | |
data FuzzyLikeFieldQuery Source #
Constructors
Instances
| Eq FuzzyLikeFieldQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: FuzzyLikeFieldQuery -> FuzzyLikeFieldQuery -> Bool # (/=) :: FuzzyLikeFieldQuery -> FuzzyLikeFieldQuery -> Bool # | |
| Show FuzzyLikeFieldQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> FuzzyLikeFieldQuery -> ShowS # show :: FuzzyLikeFieldQuery -> String # showList :: [FuzzyLikeFieldQuery] -> ShowS # | |
| ToJSON FuzzyLikeFieldQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: FuzzyLikeFieldQuery -> Value # toEncoding :: FuzzyLikeFieldQuery -> Encoding # toJSONList :: [FuzzyLikeFieldQuery] -> Value # toEncodingList :: [FuzzyLikeFieldQuery] -> Encoding # | |
| FromJSON FuzzyLikeFieldQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser FuzzyLikeFieldQuery # parseJSONList :: Value -> Parser [FuzzyLikeFieldQuery] # | |
data FuzzyQuery Source #
Constructors
| FuzzyQuery | |
Instances
| Eq FuzzyQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show FuzzyQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> FuzzyQuery -> ShowS # show :: FuzzyQuery -> String # showList :: [FuzzyQuery] -> ShowS # | |
| ToJSON FuzzyQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: FuzzyQuery -> Value # toEncoding :: FuzzyQuery -> Encoding # toJSONList :: [FuzzyQuery] -> Value # toEncodingList :: [FuzzyQuery] -> Encoding # | |
| FromJSON FuzzyQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
data HasChildQuery Source #
Constructors
| HasChildQuery | |
Instances
| Eq HasChildQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: HasChildQuery -> HasChildQuery -> Bool # (/=) :: HasChildQuery -> HasChildQuery -> Bool # | |
| Show HasChildQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> HasChildQuery -> ShowS # show :: HasChildQuery -> String # showList :: [HasChildQuery] -> ShowS # | |
| ToJSON HasChildQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: HasChildQuery -> Value # toEncoding :: HasChildQuery -> Encoding # toJSONList :: [HasChildQuery] -> Value # toEncodingList :: [HasChildQuery] -> Encoding # | |
| FromJSON HasChildQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser HasChildQuery # parseJSONList :: Value -> Parser [HasChildQuery] # | |
data HasParentQuery Source #
Constructors
| HasParentQuery | |
Instances
| Eq HasParentQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: HasParentQuery -> HasParentQuery -> Bool # (/=) :: HasParentQuery -> HasParentQuery -> Bool # | |
| Show HasParentQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> HasParentQuery -> ShowS # show :: HasParentQuery -> String # showList :: [HasParentQuery] -> ShowS # | |
| ToJSON HasParentQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: HasParentQuery -> Value # toEncoding :: HasParentQuery -> Encoding # toJSONList :: [HasParentQuery] -> Value # toEncodingList :: [HasParentQuery] -> Encoding # | |
| FromJSON HasParentQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser HasParentQuery # parseJSONList :: Value -> Parser [HasParentQuery] # | |
data IndicesQuery Source #
Constructors
| IndicesQuery | |
Fields | |
Instances
| Eq IndicesQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show IndicesQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> IndicesQuery -> ShowS # show :: IndicesQuery -> String # showList :: [IndicesQuery] -> ShowS # | |
| ToJSON IndicesQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: IndicesQuery -> Value # toEncoding :: IndicesQuery -> Encoding # toJSONList :: [IndicesQuery] -> Value # toEncodingList :: [IndicesQuery] -> Encoding # | |
| FromJSON IndicesQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
data MoreLikeThisQuery Source #
Constructors
Instances
| Eq MoreLikeThisQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: MoreLikeThisQuery -> MoreLikeThisQuery -> Bool # (/=) :: MoreLikeThisQuery -> MoreLikeThisQuery -> Bool # | |
| Show MoreLikeThisQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> MoreLikeThisQuery -> ShowS # show :: MoreLikeThisQuery -> String # showList :: [MoreLikeThisQuery] -> ShowS # | |
| ToJSON MoreLikeThisQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: MoreLikeThisQuery -> Value # toEncoding :: MoreLikeThisQuery -> Encoding # toJSONList :: [MoreLikeThisQuery] -> Value # toEncodingList :: [MoreLikeThisQuery] -> Encoding # | |
| FromJSON MoreLikeThisQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser MoreLikeThisQuery # parseJSONList :: Value -> Parser [MoreLikeThisQuery] # | |
data MoreLikeThisFieldQuery Source #
Constructors
Instances
| Eq MoreLikeThisFieldQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: MoreLikeThisFieldQuery -> MoreLikeThisFieldQuery -> Bool # (/=) :: MoreLikeThisFieldQuery -> MoreLikeThisFieldQuery -> Bool # | |
| Show MoreLikeThisFieldQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> MoreLikeThisFieldQuery -> ShowS # show :: MoreLikeThisFieldQuery -> String # showList :: [MoreLikeThisFieldQuery] -> ShowS # | |
| ToJSON MoreLikeThisFieldQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: MoreLikeThisFieldQuery -> Value # toEncoding :: MoreLikeThisFieldQuery -> Encoding # toJSONList :: [MoreLikeThisFieldQuery] -> Value # | |
| FromJSON MoreLikeThisFieldQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser MoreLikeThisFieldQuery # parseJSONList :: Value -> Parser [MoreLikeThisFieldQuery] # | |
data NestedQuery Source #
Constructors
| NestedQuery | |
Fields | |
Instances
| Eq NestedQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show NestedQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> NestedQuery -> ShowS # show :: NestedQuery -> String # showList :: [NestedQuery] -> ShowS # | |
| ToJSON NestedQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: NestedQuery -> Value # toEncoding :: NestedQuery -> Encoding # toJSONList :: [NestedQuery] -> Value # toEncodingList :: [NestedQuery] -> Encoding # | |
| FromJSON NestedQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
data PrefixQuery Source #
Constructors
| PrefixQuery | |
Fields | |
Instances
| Eq PrefixQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show PrefixQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> PrefixQuery -> ShowS # show :: PrefixQuery -> String # showList :: [PrefixQuery] -> ShowS # | |
| ToJSON PrefixQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: PrefixQuery -> Value # toEncoding :: PrefixQuery -> Encoding # toJSONList :: [PrefixQuery] -> Value # toEncodingList :: [PrefixQuery] -> Encoding # | |
| FromJSON PrefixQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
data QueryStringQuery Source #
Constructors
Instances
| Eq QueryStringQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: QueryStringQuery -> QueryStringQuery -> Bool # (/=) :: QueryStringQuery -> QueryStringQuery -> Bool # | |
| Show QueryStringQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> QueryStringQuery -> ShowS # show :: QueryStringQuery -> String # showList :: [QueryStringQuery] -> ShowS # | |
| ToJSON QueryStringQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: QueryStringQuery -> Value # toEncoding :: QueryStringQuery -> Encoding # toJSONList :: [QueryStringQuery] -> Value # toEncodingList :: [QueryStringQuery] -> Encoding # | |
| FromJSON QueryStringQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser QueryStringQuery # parseJSONList :: Value -> Parser [QueryStringQuery] # | |
data SimpleQueryStringQuery Source #
Constructors
Instances
| Eq SimpleQueryStringQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: SimpleQueryStringQuery -> SimpleQueryStringQuery -> Bool # (/=) :: SimpleQueryStringQuery -> SimpleQueryStringQuery -> Bool # | |
| Show SimpleQueryStringQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> SimpleQueryStringQuery -> ShowS # show :: SimpleQueryStringQuery -> String # showList :: [SimpleQueryStringQuery] -> ShowS # | |
| ToJSON SimpleQueryStringQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: SimpleQueryStringQuery -> Value # toEncoding :: SimpleQueryStringQuery -> Encoding # toJSONList :: [SimpleQueryStringQuery] -> Value # | |
| FromJSON SimpleQueryStringQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser SimpleQueryStringQuery # parseJSONList :: Value -> Parser [SimpleQueryStringQuery] # | |
data RangeQuery Source #
Constructors
| RangeQuery | |
Fields | |
Instances
| Eq RangeQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show RangeQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> RangeQuery -> ShowS # show :: RangeQuery -> String # showList :: [RangeQuery] -> ShowS # | |
| ToJSON RangeQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: RangeQuery -> Value # toEncoding :: RangeQuery -> Encoding # toJSONList :: [RangeQuery] -> Value # toEncodingList :: [RangeQuery] -> Encoding # | |
| FromJSON RangeQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
data RegexpQuery Source #
Constructors
| RegexpQuery | |
Fields | |
Instances
| Eq RegexpQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
| Show RegexpQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> RegexpQuery -> ShowS # show :: RegexpQuery -> String # showList :: [RegexpQuery] -> ShowS # | |
| ToJSON RegexpQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: RegexpQuery -> Value # toEncoding :: RegexpQuery -> Encoding # toJSONList :: [RegexpQuery] -> Value # toEncodingList :: [RegexpQuery] -> Encoding # | |
| FromJSON RegexpQuery Source # | |
Defined in Database.Bloodhound.Internal.Query | |
newtype QueryString Source #
QueryString is used to wrap query text bodies, be they human written or not.
Constructors
| QueryString Text |
Instances
| Eq QueryString Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show QueryString Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> QueryString -> ShowS # show :: QueryString -> String # showList :: [QueryString] -> ShowS # | |
| ToJSON QueryString Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: QueryString -> Value # toEncoding :: QueryString -> Encoding # toJSONList :: [QueryString] -> Value # toEncodingList :: [QueryString] -> Encoding # | |
| FromJSON QueryString Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
newtype SearchTemplateId Source #
Constructors
| SearchTemplateId Text |
Instances
| Eq SearchTemplateId Source # | |
Defined in Database.Bloodhound.Types Methods (==) :: SearchTemplateId -> SearchTemplateId -> Bool # (/=) :: SearchTemplateId -> SearchTemplateId -> Bool # | |
| Show SearchTemplateId Source # | |
Defined in Database.Bloodhound.Types Methods showsPrec :: Int -> SearchTemplateId -> ShowS # show :: SearchTemplateId -> String # showList :: [SearchTemplateId] -> ShowS # | |
| ToJSON SearchTemplateId Source # | |
Defined in Database.Bloodhound.Types Methods toJSON :: SearchTemplateId -> Value # toEncoding :: SearchTemplateId -> Encoding # toJSONList :: [SearchTemplateId] -> Value # toEncodingList :: [SearchTemplateId] -> Encoding # | |
newtype SearchTemplateSource Source #
Constructors
| SearchTemplateSource Text |
Instances
| Eq SearchTemplateSource Source # | |
Defined in Database.Bloodhound.Types Methods (==) :: SearchTemplateSource -> SearchTemplateSource -> Bool # (/=) :: SearchTemplateSource -> SearchTemplateSource -> Bool # | |
| Show SearchTemplateSource Source # | |
Defined in Database.Bloodhound.Types Methods showsPrec :: Int -> SearchTemplateSource -> ShowS # show :: SearchTemplateSource -> String # showList :: [SearchTemplateSource] -> ShowS # | |
| ToJSON SearchTemplateSource Source # | |
Defined in Database.Bloodhound.Types Methods toJSON :: SearchTemplateSource -> Value # toEncoding :: SearchTemplateSource -> Encoding # toJSONList :: [SearchTemplateSource] -> Value # toEncodingList :: [SearchTemplateSource] -> Encoding # | |
| FromJSON SearchTemplateSource Source # | |
Defined in Database.Bloodhound.Types Methods parseJSON :: Value -> Parser SearchTemplateSource # parseJSONList :: Value -> Parser [SearchTemplateSource] # | |
data SearchTemplate Source #
Constructors
| SearchTemplate | |
Instances
| Eq SearchTemplate Source # | |
Defined in Database.Bloodhound.Types Methods (==) :: SearchTemplate -> SearchTemplate -> Bool # (/=) :: SearchTemplate -> SearchTemplate -> Bool # | |
| Show SearchTemplate Source # | |
Defined in Database.Bloodhound.Types Methods showsPrec :: Int -> SearchTemplate -> ShowS # show :: SearchTemplate -> String # showList :: [SearchTemplate] -> ShowS # | |
| ToJSON SearchTemplate Source # | |
Defined in Database.Bloodhound.Types Methods toJSON :: SearchTemplate -> Value # toEncoding :: SearchTemplate -> Encoding # toJSONList :: [SearchTemplate] -> Value # toEncodingList :: [SearchTemplate] -> Encoding # | |
data GetTemplateScript Source #
Constructors
| GetTemplateScript | |
Instances
| Eq GetTemplateScript Source # | |
Defined in Database.Bloodhound.Types Methods (==) :: GetTemplateScript -> GetTemplateScript -> Bool # (/=) :: GetTemplateScript -> GetTemplateScript -> Bool # | |
| Show GetTemplateScript Source # | |
Defined in Database.Bloodhound.Types Methods showsPrec :: Int -> GetTemplateScript -> ShowS # show :: GetTemplateScript -> String # showList :: [GetTemplateScript] -> ShowS # | |
| FromJSON GetTemplateScript Source # | |
Defined in Database.Bloodhound.Types Methods parseJSON :: Value -> Parser GetTemplateScript # parseJSONList :: Value -> Parser [GetTemplateScript] # | |
newtype TemplateQueryKeyValuePairs Source #
Constructors
| TemplateQueryKeyValuePairs (KeyMap TemplateQueryValue) |
Instances
data WildcardQuery Source #
Constructors
| WildcardQuery | |
Fields | |
Instances
| Eq WildcardQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: WildcardQuery -> WildcardQuery -> Bool # (/=) :: WildcardQuery -> WildcardQuery -> Bool # | |
| Show WildcardQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> WildcardQuery -> ShowS # show :: WildcardQuery -> String # showList :: [WildcardQuery] -> ShowS # | |
| ToJSON WildcardQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: WildcardQuery -> Value # toEncoding :: WildcardQuery -> Encoding # toJSONList :: [WildcardQuery] -> Value # toEncodingList :: [WildcardQuery] -> Encoding # | |
| FromJSON WildcardQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser WildcardQuery # parseJSONList :: Value -> Parser [WildcardQuery] # | |
data BooleanOperator Source #
BooleanOperator is the usual And/Or operators with an ES compatible
JSON encoding baked in. Used all over the place.
Instances
| Eq BooleanOperator Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: BooleanOperator -> BooleanOperator -> Bool # (/=) :: BooleanOperator -> BooleanOperator -> Bool # | |
| Show BooleanOperator Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> BooleanOperator -> ShowS # show :: BooleanOperator -> String # showList :: [BooleanOperator] -> ShowS # | |
| ToJSON BooleanOperator Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: BooleanOperator -> Value # toEncoding :: BooleanOperator -> Encoding # toJSONList :: [BooleanOperator] -> Value # toEncodingList :: [BooleanOperator] -> Encoding # | |
| FromJSON BooleanOperator Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser BooleanOperator # parseJSONList :: Value -> Parser [BooleanOperator] # | |
data ZeroTermsQuery Source #
Constructors
| ZeroTermsNone | |
| ZeroTermsAll |
Instances
| Eq ZeroTermsQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: ZeroTermsQuery -> ZeroTermsQuery -> Bool # (/=) :: ZeroTermsQuery -> ZeroTermsQuery -> Bool # | |
| Show ZeroTermsQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> ZeroTermsQuery -> ShowS # show :: ZeroTermsQuery -> String # showList :: [ZeroTermsQuery] -> ShowS # | |
| ToJSON ZeroTermsQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: ZeroTermsQuery -> Value # toEncoding :: ZeroTermsQuery -> Encoding # toJSONList :: [ZeroTermsQuery] -> Value # toEncodingList :: [ZeroTermsQuery] -> Encoding # | |
| FromJSON ZeroTermsQuery Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser ZeroTermsQuery # parseJSONList :: Value -> Parser [ZeroTermsQuery] # | |
newtype CutoffFrequency Source #
Constructors
| CutoffFrequency Double |
Instances
| Eq CutoffFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: CutoffFrequency -> CutoffFrequency -> Bool # (/=) :: CutoffFrequency -> CutoffFrequency -> Bool # | |
| Show CutoffFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> CutoffFrequency -> ShowS # show :: CutoffFrequency -> String # showList :: [CutoffFrequency] -> ShowS # | |
| ToJSON CutoffFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: CutoffFrequency -> Value # toEncoding :: CutoffFrequency -> Encoding # toJSONList :: [CutoffFrequency] -> Value # toEncodingList :: [CutoffFrequency] -> Encoding # | |
| FromJSON CutoffFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser CutoffFrequency # parseJSONList :: Value -> Parser [CutoffFrequency] # | |
newtype TokenFilter Source #
Constructors
| TokenFilter Text |
Instances
| Eq TokenFilter Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show TokenFilter Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> TokenFilter -> ShowS # show :: TokenFilter -> String # showList :: [TokenFilter] -> ShowS # | |
| ToJSON TokenFilter Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: TokenFilter -> Value # toEncoding :: TokenFilter -> Encoding # toJSONList :: [TokenFilter] -> Value # toEncodingList :: [TokenFilter] -> Encoding # | |
| FromJSON TokenFilter Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
newtype CharFilter Source #
Constructors
| CharFilter Text |
Instances
| Eq CharFilter Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show CharFilter Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> CharFilter -> ShowS # show :: CharFilter -> String # showList :: [CharFilter] -> ShowS # | |
| ToJSON CharFilter Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: CharFilter -> Value # toEncoding :: CharFilter -> Encoding # toJSONList :: [CharFilter] -> Value # toEncodingList :: [CharFilter] -> Encoding # | |
| FromJSON CharFilter Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
newtype MaxExpansions Source #
Constructors
| MaxExpansions Int |
Instances
| Eq MaxExpansions Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: MaxExpansions -> MaxExpansions -> Bool # (/=) :: MaxExpansions -> MaxExpansions -> Bool # | |
| Show MaxExpansions Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> MaxExpansions -> ShowS # show :: MaxExpansions -> String # showList :: [MaxExpansions] -> ShowS # | |
| ToJSON MaxExpansions Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: MaxExpansions -> Value # toEncoding :: MaxExpansions -> Encoding # toJSONList :: [MaxExpansions] -> Value # toEncodingList :: [MaxExpansions] -> Encoding # | |
| FromJSON MaxExpansions Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser MaxExpansions # parseJSONList :: Value -> Parser [MaxExpansions] # | |
Lenient, if set to true, will cause format based failures to be
ignored. I don't know what the bloody default is, Elasticsearch
documentation didn't say what it was. Let me know if you figure it out.
data MatchQueryType Source #
Constructors
| MatchPhrase | |
| MatchPhrasePrefix |
Instances
| Eq MatchQueryType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: MatchQueryType -> MatchQueryType -> Bool # (/=) :: MatchQueryType -> MatchQueryType -> Bool # | |
| Show MatchQueryType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> MatchQueryType -> ShowS # show :: MatchQueryType -> String # showList :: [MatchQueryType] -> ShowS # | |
| ToJSON MatchQueryType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: MatchQueryType -> Value # toEncoding :: MatchQueryType -> Encoding # toJSONList :: [MatchQueryType] -> Value # toEncodingList :: [MatchQueryType] -> Encoding # | |
| FromJSON MatchQueryType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser MatchQueryType # parseJSONList :: Value -> Parser [MatchQueryType] # | |
data MultiMatchQueryType Source #
Constructors
| MultiMatchBestFields | |
| MultiMatchMostFields | |
| MultiMatchCrossFields | |
| MultiMatchPhrase | |
| MultiMatchPhrasePrefix |
Instances
| Eq MultiMatchQueryType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: MultiMatchQueryType -> MultiMatchQueryType -> Bool # (/=) :: MultiMatchQueryType -> MultiMatchQueryType -> Bool # | |
| Show MultiMatchQueryType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> MultiMatchQueryType -> ShowS # show :: MultiMatchQueryType -> String # showList :: [MultiMatchQueryType] -> ShowS # | |
| ToJSON MultiMatchQueryType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: MultiMatchQueryType -> Value # toEncoding :: MultiMatchQueryType -> Encoding # toJSONList :: [MultiMatchQueryType] -> Value # toEncodingList :: [MultiMatchQueryType] -> Encoding # | |
| FromJSON MultiMatchQueryType Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser MultiMatchQueryType # parseJSONList :: Value -> Parser [MultiMatchQueryType] # | |
newtype Tiebreaker Source #
Constructors
| Tiebreaker Double |
Instances
| Eq Tiebreaker Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show Tiebreaker Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> Tiebreaker -> ShowS # show :: Tiebreaker -> String # showList :: [Tiebreaker] -> ShowS # | |
| ToJSON Tiebreaker Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: Tiebreaker -> Value # toEncoding :: Tiebreaker -> Encoding # toJSONList :: [Tiebreaker] -> Value # toEncodingList :: [Tiebreaker] -> Encoding # | |
| FromJSON Tiebreaker Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
newtype MinimumMatch Source #
MinimumMatch controls how many should clauses in the bool query should
match. Can be an absolute value (2) or a percentage (30%) or a
combination of both.
Constructors
| MinimumMatch Int |
Instances
| Eq MinimumMatch Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show MinimumMatch Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> MinimumMatch -> ShowS # show :: MinimumMatch -> String # showList :: [MinimumMatch] -> ShowS # | |
| ToJSON MinimumMatch Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: MinimumMatch -> Value # toEncoding :: MinimumMatch -> Encoding # toJSONList :: [MinimumMatch] -> Value # toEncodingList :: [MinimumMatch] -> Encoding # | |
| FromJSON MinimumMatch Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
newtype DisableCoord Source #
Constructors
| DisableCoord Bool |
Instances
| Eq DisableCoord Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show DisableCoord Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> DisableCoord -> ShowS # show :: DisableCoord -> String # showList :: [DisableCoord] -> ShowS # | |
| ToJSON DisableCoord Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: DisableCoord -> Value # toEncoding :: DisableCoord -> Encoding # toJSONList :: [DisableCoord] -> Value # toEncodingList :: [DisableCoord] -> Encoding # | |
| FromJSON DisableCoord Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
data CommonMinimumMatch Source #
Instances
| Eq CommonMinimumMatch Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: CommonMinimumMatch -> CommonMinimumMatch -> Bool # (/=) :: CommonMinimumMatch -> CommonMinimumMatch -> Bool # | |
| Show CommonMinimumMatch Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> CommonMinimumMatch -> ShowS # show :: CommonMinimumMatch -> String # showList :: [CommonMinimumMatch] -> ShowS # | |
| ToJSON CommonMinimumMatch Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: CommonMinimumMatch -> Value # toEncoding :: CommonMinimumMatch -> Encoding # toJSONList :: [CommonMinimumMatch] -> Value # toEncodingList :: [CommonMinimumMatch] -> Encoding # | |
| FromJSON CommonMinimumMatch Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser CommonMinimumMatch # parseJSONList :: Value -> Parser [CommonMinimumMatch] # | |
data MinimumMatchHighLow Source #
Constructors
| MinimumMatchHighLow | |
Fields | |
Instances
| Eq MinimumMatchHighLow Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: MinimumMatchHighLow -> MinimumMatchHighLow -> Bool # (/=) :: MinimumMatchHighLow -> MinimumMatchHighLow -> Bool # | |
| Show MinimumMatchHighLow Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> MinimumMatchHighLow -> ShowS # show :: MinimumMatchHighLow -> String # showList :: [MinimumMatchHighLow] -> ShowS # | |
newtype PrefixLength Source #
PrefixLength is the prefix length used in queries, defaults to 0.
Constructors
| PrefixLength Int |
Instances
| Eq PrefixLength Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show PrefixLength Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> PrefixLength -> ShowS # show :: PrefixLength -> String # showList :: [PrefixLength] -> ShowS # | |
| ToJSON PrefixLength Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: PrefixLength -> Value # toEncoding :: PrefixLength -> Encoding # toJSONList :: [PrefixLength] -> Value # toEncodingList :: [PrefixLength] -> Encoding # | |
| FromJSON PrefixLength Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
Fuzziness value as a number or AUTO.
See:
https://www.elastic.co/guide/en/elasticsearch/reference/current/common-options.html#fuzziness
Constructors
| Fuzziness Double | |
| FuzzinessAuto |
newtype IgnoreTermFrequency Source #
Constructors
| IgnoreTermFrequency Bool |
Instances
| Eq IgnoreTermFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: IgnoreTermFrequency -> IgnoreTermFrequency -> Bool # (/=) :: IgnoreTermFrequency -> IgnoreTermFrequency -> Bool # | |
| Show IgnoreTermFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> IgnoreTermFrequency -> ShowS # show :: IgnoreTermFrequency -> String # showList :: [IgnoreTermFrequency] -> ShowS # | |
| ToJSON IgnoreTermFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: IgnoreTermFrequency -> Value # toEncoding :: IgnoreTermFrequency -> Encoding # toJSONList :: [IgnoreTermFrequency] -> Value # toEncodingList :: [IgnoreTermFrequency] -> Encoding # | |
| FromJSON IgnoreTermFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser IgnoreTermFrequency # parseJSONList :: Value -> Parser [IgnoreTermFrequency] # | |
newtype MaxQueryTerms Source #
Constructors
| MaxQueryTerms Int |
Instances
| Eq MaxQueryTerms Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: MaxQueryTerms -> MaxQueryTerms -> Bool # (/=) :: MaxQueryTerms -> MaxQueryTerms -> Bool # | |
| Show MaxQueryTerms Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> MaxQueryTerms -> ShowS # show :: MaxQueryTerms -> String # showList :: [MaxQueryTerms] -> ShowS # | |
| ToJSON MaxQueryTerms Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: MaxQueryTerms -> Value # toEncoding :: MaxQueryTerms -> Encoding # toJSONList :: [MaxQueryTerms] -> Value # toEncodingList :: [MaxQueryTerms] -> Encoding # | |
| FromJSON MaxQueryTerms Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser MaxQueryTerms # parseJSONList :: Value -> Parser [MaxQueryTerms] # | |
newtype AggregateParentScore Source #
Indicates whether the relevance score of a matching parent document is aggregated into its child documents.
Constructors
| AggregateParentScore Bool |
Instances
| Eq AggregateParentScore Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: AggregateParentScore -> AggregateParentScore -> Bool # (/=) :: AggregateParentScore -> AggregateParentScore -> Bool # | |
| Show AggregateParentScore Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> AggregateParentScore -> ShowS # show :: AggregateParentScore -> String # showList :: [AggregateParentScore] -> ShowS # | |
| ToJSON AggregateParentScore Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: AggregateParentScore -> Value # toEncoding :: AggregateParentScore -> Encoding # toJSONList :: [AggregateParentScore] -> Value # toEncodingList :: [AggregateParentScore] -> Encoding # | |
| FromJSON AggregateParentScore Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser AggregateParentScore # parseJSONList :: Value -> Parser [AggregateParentScore] # | |
newtype IgnoreUnmapped Source #
Indicates whether to ignore an unmapped parent_type and not return any documents instead of an error.
Constructors
| IgnoreUnmapped Bool |
Instances
| Eq IgnoreUnmapped Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: IgnoreUnmapped -> IgnoreUnmapped -> Bool # (/=) :: IgnoreUnmapped -> IgnoreUnmapped -> Bool # | |
| Show IgnoreUnmapped Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> IgnoreUnmapped -> ShowS # show :: IgnoreUnmapped -> String # showList :: [IgnoreUnmapped] -> ShowS # | |
| ToJSON IgnoreUnmapped Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: IgnoreUnmapped -> Value # toEncoding :: IgnoreUnmapped -> Encoding # toJSONList :: [IgnoreUnmapped] -> Value # toEncodingList :: [IgnoreUnmapped] -> Encoding # | |
| FromJSON IgnoreUnmapped Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser IgnoreUnmapped # parseJSONList :: Value -> Parser [IgnoreUnmapped] # | |
newtype MinChildren Source #
Maximum number of child documents that match the query allowed for a returned parent document. If the parent document exceeds this limit, it is excluded from the search results.
Constructors
| MinChildren Int |
Instances
| Eq MinChildren Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show MinChildren Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> MinChildren -> ShowS # show :: MinChildren -> String # showList :: [MinChildren] -> ShowS # | |
| ToJSON MinChildren Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: MinChildren -> Value # toEncoding :: MinChildren -> Encoding # toJSONList :: [MinChildren] -> Value # toEncodingList :: [MinChildren] -> Encoding # | |
| FromJSON MinChildren Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
newtype MaxChildren Source #
Minimum number of child documents that match the query required to match the query for a returned parent document. If the parent document does not meet this limit, it is excluded from the search results.
Constructors
| MaxChildren Int |
Instances
| Eq MaxChildren Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show MaxChildren Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> MaxChildren -> ShowS # show :: MaxChildren -> String # showList :: [MaxChildren] -> ShowS # | |
| ToJSON MaxChildren Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: MaxChildren -> Value # toEncoding :: MaxChildren -> Encoding # toJSONList :: [MaxChildren] -> Value # toEncodingList :: [MaxChildren] -> Encoding # | |
| FromJSON MaxChildren Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
Constructors
| ScoreTypeMax | |
| ScoreTypeSum | |
| ScoreTypeAvg | |
| ScoreTypeNone |
Constructors
| InnerHits | |
Fields | |
newtype RelationName Source #
RelationName describes a relation role between parend and child Documents
in a Join relarionship: https://www.elastic.co/guide/en/elasticsearch/reference/current/parent-join.html
Constructors
| RelationName Text |
Instances
| Eq RelationName Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Read RelationName Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods readsPrec :: Int -> ReadS RelationName # readList :: ReadS [RelationName] # | |
| Show RelationName Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> RelationName -> ShowS # show :: RelationName -> String # showList :: [RelationName] -> ShowS # | |
| ToJSON RelationName Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: RelationName -> Value # toEncoding :: RelationName -> Encoding # toJSONList :: [RelationName] -> Value # toEncodingList :: [RelationName] -> Encoding # | |
| FromJSON RelationName Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
newtype BoostTerms Source #
Constructors
| BoostTerms Double |
Instances
| Eq BoostTerms Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show BoostTerms Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> BoostTerms -> ShowS # show :: BoostTerms -> String # showList :: [BoostTerms] -> ShowS # | |
| ToJSON BoostTerms Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: BoostTerms -> Value # toEncoding :: BoostTerms -> Encoding # toJSONList :: [BoostTerms] -> Value # toEncodingList :: [BoostTerms] -> Encoding # | |
| FromJSON BoostTerms Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
newtype MaxWordLength Source #
Constructors
| MaxWordLength Int |
Instances
| Eq MaxWordLength Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: MaxWordLength -> MaxWordLength -> Bool # (/=) :: MaxWordLength -> MaxWordLength -> Bool # | |
| Show MaxWordLength Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> MaxWordLength -> ShowS # show :: MaxWordLength -> String # showList :: [MaxWordLength] -> ShowS # | |
| ToJSON MaxWordLength Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: MaxWordLength -> Value # toEncoding :: MaxWordLength -> Encoding # toJSONList :: [MaxWordLength] -> Value # toEncodingList :: [MaxWordLength] -> Encoding # | |
| FromJSON MaxWordLength Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser MaxWordLength # parseJSONList :: Value -> Parser [MaxWordLength] # | |
newtype MinWordLength Source #
Constructors
| MinWordLength Int |
Instances
| Eq MinWordLength Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: MinWordLength -> MinWordLength -> Bool # (/=) :: MinWordLength -> MinWordLength -> Bool # | |
| Show MinWordLength Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> MinWordLength -> ShowS # show :: MinWordLength -> String # showList :: [MinWordLength] -> ShowS # | |
| ToJSON MinWordLength Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: MinWordLength -> Value # toEncoding :: MinWordLength -> Encoding # toJSONList :: [MinWordLength] -> Value # toEncodingList :: [MinWordLength] -> Encoding # | |
| FromJSON MinWordLength Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser MinWordLength # parseJSONList :: Value -> Parser [MinWordLength] # | |
newtype MaxDocFrequency Source #
Constructors
| MaxDocFrequency Int |
Instances
| Eq MaxDocFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: MaxDocFrequency -> MaxDocFrequency -> Bool # (/=) :: MaxDocFrequency -> MaxDocFrequency -> Bool # | |
| Show MaxDocFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> MaxDocFrequency -> ShowS # show :: MaxDocFrequency -> String # showList :: [MaxDocFrequency] -> ShowS # | |
| ToJSON MaxDocFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: MaxDocFrequency -> Value # toEncoding :: MaxDocFrequency -> Encoding # toJSONList :: [MaxDocFrequency] -> Value # toEncodingList :: [MaxDocFrequency] -> Encoding # | |
| FromJSON MaxDocFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser MaxDocFrequency # parseJSONList :: Value -> Parser [MaxDocFrequency] # | |
newtype MinDocFrequency Source #
Constructors
| MinDocFrequency Int |
Instances
| Eq MinDocFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: MinDocFrequency -> MinDocFrequency -> Bool # (/=) :: MinDocFrequency -> MinDocFrequency -> Bool # | |
| Show MinDocFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> MinDocFrequency -> ShowS # show :: MinDocFrequency -> String # showList :: [MinDocFrequency] -> ShowS # | |
| ToJSON MinDocFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: MinDocFrequency -> Value # toEncoding :: MinDocFrequency -> Encoding # toJSONList :: [MinDocFrequency] -> Value # toEncodingList :: [MinDocFrequency] -> Encoding # | |
| FromJSON MinDocFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser MinDocFrequency # parseJSONList :: Value -> Parser [MinDocFrequency] # | |
newtype PhraseSlop Source #
PhraseSlop sets the default slop for phrases, 0 means exact
phrase matches. Default is 0.
Constructors
| PhraseSlop Int |
Instances
| Eq PhraseSlop Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show PhraseSlop Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> PhraseSlop -> ShowS # show :: PhraseSlop -> String # showList :: [PhraseSlop] -> ShowS # | |
| ToJSON PhraseSlop Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: PhraseSlop -> Value # toEncoding :: PhraseSlop -> Encoding # toJSONList :: [PhraseSlop] -> Value # toEncodingList :: [PhraseSlop] -> Encoding # | |
| FromJSON PhraseSlop Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
newtype MinimumTermFrequency Source #
Constructors
| MinimumTermFrequency Int |
Instances
| Eq MinimumTermFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: MinimumTermFrequency -> MinimumTermFrequency -> Bool # (/=) :: MinimumTermFrequency -> MinimumTermFrequency -> Bool # | |
| Show MinimumTermFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> MinimumTermFrequency -> ShowS # show :: MinimumTermFrequency -> String # showList :: [MinimumTermFrequency] -> ShowS # | |
| ToJSON MinimumTermFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: MinimumTermFrequency -> Value # toEncoding :: MinimumTermFrequency -> Encoding # toJSONList :: [MinimumTermFrequency] -> Value # toEncodingList :: [MinimumTermFrequency] -> Encoding # | |
| FromJSON MinimumTermFrequency Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser MinimumTermFrequency # parseJSONList :: Value -> Parser [MinimumTermFrequency] # | |
newtype PercentMatch Source #
Constructors
| PercentMatch Double |
Instances
| Eq PercentMatch Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show PercentMatch Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> PercentMatch -> ShowS # show :: PercentMatch -> String # showList :: [PercentMatch] -> ShowS # | |
| ToJSON PercentMatch Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: PercentMatch -> Value # toEncoding :: PercentMatch -> Encoding # toJSONList :: [PercentMatch] -> Value # toEncodingList :: [PercentMatch] -> Encoding # | |
| FromJSON PercentMatch Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
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 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 Mappings is currently incomplete, for
now the mapping API verbiage expects a ToJSONable blob.
Indexes have mappings, mappings are schemas for the documents contained in the index. I'd recommend having only one mapping per index, always having a mapping, and keeping different kinds of documents separated if possible.
Constructors
| Mapping | |
Fields | |
data UpsertActionMetadata Source #
Constructors
| UA_RetryOnConflict Int | |
| UA_Version Int |
Instances
| 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 # | |
newtype AllowLeadingWildcard Source #
Allowing a wildcard at the beginning of a word (eg "*ing") is particularly
heavy, because all terms in the index need to be examined, just in case
they match. Leading wildcards can be disabled by setting
AllowLeadingWildcard to false.
Constructors
| AllowLeadingWildcard Bool |
Instances
| Eq AllowLeadingWildcard Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: AllowLeadingWildcard -> AllowLeadingWildcard -> Bool # (/=) :: AllowLeadingWildcard -> AllowLeadingWildcard -> Bool # | |
| Show AllowLeadingWildcard Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> AllowLeadingWildcard -> ShowS # show :: AllowLeadingWildcard -> String # showList :: [AllowLeadingWildcard] -> ShowS # | |
| ToJSON AllowLeadingWildcard Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: AllowLeadingWildcard -> Value # toEncoding :: AllowLeadingWildcard -> Encoding # toJSONList :: [AllowLeadingWildcard] -> Value # toEncodingList :: [AllowLeadingWildcard] -> Encoding # | |
| FromJSON AllowLeadingWildcard Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser AllowLeadingWildcard # parseJSONList :: Value -> Parser [AllowLeadingWildcard] # | |
newtype LowercaseExpanded Source #
Constructors
| LowercaseExpanded Bool |
Instances
| Eq LowercaseExpanded Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: LowercaseExpanded -> LowercaseExpanded -> Bool # (/=) :: LowercaseExpanded -> LowercaseExpanded -> Bool # | |
| Show LowercaseExpanded Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> LowercaseExpanded -> ShowS # show :: LowercaseExpanded -> String # showList :: [LowercaseExpanded] -> ShowS # | |
| ToJSON LowercaseExpanded Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: LowercaseExpanded -> Value # toEncoding :: LowercaseExpanded -> Encoding # toJSONList :: [LowercaseExpanded] -> Value # toEncodingList :: [LowercaseExpanded] -> Encoding # | |
| FromJSON LowercaseExpanded Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser LowercaseExpanded # parseJSONList :: Value -> Parser [LowercaseExpanded] # | |
newtype GeneratePhraseQueries Source #
GeneratePhraseQueries defaults to false.
Constructors
| GeneratePhraseQueries Bool |
Instances
| Eq GeneratePhraseQueries Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: GeneratePhraseQueries -> GeneratePhraseQueries -> Bool # (/=) :: GeneratePhraseQueries -> GeneratePhraseQueries -> Bool # | |
| Show GeneratePhraseQueries Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> GeneratePhraseQueries -> ShowS # show :: GeneratePhraseQueries -> String # showList :: [GeneratePhraseQueries] -> ShowS # | |
| ToJSON GeneratePhraseQueries Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: GeneratePhraseQueries -> Value # toEncoding :: GeneratePhraseQueries -> Encoding # toJSONList :: [GeneratePhraseQueries] -> Value # toEncodingList :: [GeneratePhraseQueries] -> Encoding # | |
| FromJSON GeneratePhraseQueries Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser GeneratePhraseQueries # parseJSONList :: Value -> Parser [GeneratePhraseQueries] # | |
Locale is used for string conversions - defaults to ROOT.
newtype AnalyzeWildcard Source #
By default, wildcard terms in a query are not analyzed.
Setting AnalyzeWildcard to true enables best-effort analysis.
Constructors
| AnalyzeWildcard Bool |
Instances
| Eq AnalyzeWildcard Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: AnalyzeWildcard -> AnalyzeWildcard -> Bool # (/=) :: AnalyzeWildcard -> AnalyzeWildcard -> Bool # | |
| Show AnalyzeWildcard Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> AnalyzeWildcard -> ShowS # show :: AnalyzeWildcard -> String # showList :: [AnalyzeWildcard] -> ShowS # | |
| ToJSON AnalyzeWildcard Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: AnalyzeWildcard -> Value # toEncoding :: AnalyzeWildcard -> Encoding # toJSONList :: [AnalyzeWildcard] -> Value # toEncodingList :: [AnalyzeWildcard] -> Encoding # | |
| FromJSON AnalyzeWildcard Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser AnalyzeWildcard # parseJSONList :: Value -> Parser [AnalyzeWildcard] # | |
newtype EnablePositionIncrements Source #
Constructors
| EnablePositionIncrements Bool |
Instances
| Eq EnablePositionIncrements Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods (==) :: EnablePositionIncrements -> EnablePositionIncrements -> Bool # (/=) :: EnablePositionIncrements -> EnablePositionIncrements -> Bool # | |
| Show EnablePositionIncrements Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> EnablePositionIncrements -> ShowS # show :: EnablePositionIncrements -> String # showList :: [EnablePositionIncrements] -> ShowS # | |
| ToJSON EnablePositionIncrements Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: EnablePositionIncrements -> Value # toEncoding :: EnablePositionIncrements -> Encoding # toJSONList :: [EnablePositionIncrements] -> Value # | |
| FromJSON EnablePositionIncrements Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods parseJSON :: Value -> Parser EnablePositionIncrements # parseJSONList :: Value -> Parser [EnablePositionIncrements] # | |
data SimpleQueryFlag Source #
Constructors
Instances
| Eq SimpleQueryFlag Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: SimpleQueryFlag -> SimpleQueryFlag -> Bool # (/=) :: SimpleQueryFlag -> SimpleQueryFlag -> Bool # | |
| Show SimpleQueryFlag Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> SimpleQueryFlag -> ShowS # show :: SimpleQueryFlag -> String # showList :: [SimpleQueryFlag] -> ShowS # | |
| ToJSON SimpleQueryFlag Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: SimpleQueryFlag -> Value # toEncoding :: SimpleQueryFlag -> Encoding # toJSONList :: [SimpleQueryFlag] -> Value # toEncodingList :: [SimpleQueryFlag] -> Encoding # | |
| FromJSON SimpleQueryFlag Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser SimpleQueryFlag # parseJSONList :: Value -> Parser [SimpleQueryFlag] # | |
data FieldOrFields Source #
Instances
| Eq FieldOrFields Source # | |
Defined in Database.Bloodhound.Internal.Query Methods (==) :: FieldOrFields -> FieldOrFields -> Bool # (/=) :: FieldOrFields -> FieldOrFields -> Bool # | |
| Show FieldOrFields Source # | |
Defined in Database.Bloodhound.Internal.Query Methods showsPrec :: Int -> FieldOrFields -> ShowS # show :: FieldOrFields -> String # showList :: [FieldOrFields] -> ShowS # | |
| ToJSON FieldOrFields Source # | |
Defined in Database.Bloodhound.Internal.Query Methods toJSON :: FieldOrFields -> Value # toEncoding :: FieldOrFields -> Encoding # toJSONList :: [FieldOrFields] -> Value # toEncodingList :: [FieldOrFields] -> Encoding # | |
| FromJSON FieldOrFields Source # | |
Defined in Database.Bloodhound.Internal.Query Methods parseJSON :: Value -> Parser FieldOrFields # parseJSONList :: Value -> Parser [FieldOrFields] # | |
class Semigroup a => Monoid a where #
The class of monoids (types with an associative binary operation that has an identity). Instances should satisfy the following:
- Right identity
x<>mempty= x- Left identity
mempty<>x = x- Associativity
x(<>(y<>z) = (x<>y)<>zSemigrouplaw)- Concatenation
mconcat=foldr(<>)mempty
The method names refer to the monoid of lists under concatenation, but there are many other instances.
Some types can be viewed as a monoid in more than one way,
e.g. both addition and multiplication on numbers.
In such cases we often define newtypes and make those instances
of Monoid, e.g. Sum and Product.
NOTE: Semigroup is a superclass of Monoid since base-4.11.0.0.
Minimal complete definition
Methods
Identity of mappend
>>>"Hello world" <> mempty"Hello world"
An associative operation
NOTE: This method is redundant and has the default
implementation since base-4.11.0.0.
Should it be implemented manually, since mappend = (<>)mappend is a synonym for
(<>), it is expected that the two functions are defined the same
way. In a future GHC release mappend will be removed from Monoid.
Fold a list using the monoid.
For most types, the default definition for mconcat will be
used, but the function is included in the class definition so
that an optimized version can be provided for specific types.
>>>mconcat ["Hello", " ", "Haskell", "!"]"Hello Haskell!"
Instances
| Monoid Ordering | Since: base-2.1 |
| Monoid () | Since: base-2.1 |
| Monoid ByteString | |
Defined in Data.ByteString.Internal Methods mempty :: ByteString # mappend :: ByteString -> ByteString -> ByteString # mconcat :: [ByteString] -> ByteString # | |
| Monoid ByteString | |
Defined in Data.ByteString.Lazy.Internal Methods mempty :: ByteString # mappend :: ByteString -> ByteString -> ByteString # mconcat :: [ByteString] -> ByteString # | |
| Monoid Builder | |
| Monoid Series | |
| Monoid Key | |
| Monoid More | |
| Monoid All | Since: base-2.1 |
| Monoid Any | Since: base-2.1 |
| Monoid ShortByteString | |
Defined in Data.ByteString.Short.Internal Methods mappend :: ShortByteString -> ShortByteString -> ShortByteString # mconcat :: [ShortByteString] -> ShortByteString # | |
| Monoid IntSet | |
| Monoid CookieJar | Since 1.9 |
| Monoid RequestBody | |
Defined in Network.HTTP.Client.Types Methods mempty :: RequestBody # mappend :: RequestBody -> RequestBody -> RequestBody # mconcat :: [RequestBody] -> RequestBody # | |
| Monoid Doc | |
| Monoid ByteArray | |
| Monoid ShortText | |
| Monoid CalendarDiffTime | Additive |
Defined in Data.Time.LocalTime.Internal.CalendarDiffTime Methods mappend :: CalendarDiffTime -> CalendarDiffTime -> CalendarDiffTime # mconcat :: [CalendarDiffTime] -> CalendarDiffTime # | |
| Monoid CalendarDiffDays | Additive |
Defined in Data.Time.Calendar.CalendarDiffDays Methods mappend :: CalendarDiffDays -> CalendarDiffDays -> CalendarDiffDays # mconcat :: [CalendarDiffDays] -> CalendarDiffDays # | |
| Monoid [a] | Since: base-2.1 |
| Semigroup a => Monoid (Maybe a) | Lift a semigroup into Since 4.11.0: constraint on inner Since: base-2.1 |
| Monoid a => Monoid (IO a) | Since: base-4.9.0.0 |
| Monoid p => Monoid (Par1 p) | Since: base-4.12.0.0 |
| Monoid a => Monoid (Solo a) | |
| Monoid (IResult a) | |
| Monoid (Result a) | |
| Monoid (Parser a) | |
| Monoid (KeyMap v) | |
| (Ord a, Bounded a) => Monoid (Min a) | Since: base-4.9.0.0 |
| (Ord a, Bounded a) => Monoid (Max a) | Since: base-4.9.0.0 |
| Monoid m => Monoid (WrappedMonoid m) | Since: base-4.9.0.0 |
Defined in Data.Semigroup Methods mempty :: WrappedMonoid m # mappend :: WrappedMonoid m -> WrappedMonoid m -> WrappedMonoid m # mconcat :: [WrappedMonoid m] -> WrappedMonoid m # | |
| Semigroup a => Monoid (Option a) | Since: base-4.9.0.0 |
| Monoid a => Monoid (Identity a) | Since: base-4.9.0.0 |
| Monoid (First a) | Since: base-2.1 |
| Monoid (Last a) | Since: base-2.1 |
| Monoid a => Monoid (Dual a) | Since: base-2.1 |
| Monoid (Endo a) | Since: base-2.1 |
| Num a => Monoid (Sum a) | Since: base-2.1 |
| Num a => Monoid (Product a) | Since: base-2.1 |
| Monoid a => Monoid (Down a) | Since: base-4.11.0.0 |
| Monoid s => Monoid (CI s) | |
| Monoid (IntMap a) | |
| Monoid (Seq a) | |
| Ord a => Monoid (Set a) | |
| Monoid (DList a) | |
| Monoid (Doc a) | |
| Monoid (PrimArray a) | Since: primitive-0.6.4.0 |
| Monoid (SmallArray a) | |
Defined in Data.Primitive.SmallArray Methods mempty :: SmallArray a # mappend :: SmallArray a -> SmallArray a -> SmallArray a # mconcat :: [SmallArray a] -> SmallArray a # | |
| Monoid (Array a) | |
| Semigroup a => Monoid (Maybe a) | |
| (Hashable a, Eq a) => Monoid (HashSet a) | O(n+m) To obtain good performance, the smaller set must be presented as the first argument. Examples
|
| Storable a => Monoid (Vector a) | |
| Prim a => Monoid (Vector a) | |
| Monoid (Vector a) | |
| Monoid (MergeSet a) | |
| Monoid (SearchHits a) Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods mempty :: SearchHits a # mappend :: SearchHits a -> SearchHits a -> SearchHits a # mconcat :: [SearchHits a] -> SearchHits a # | |
| Monoid b => Monoid (a -> b) | Since: base-2.1 |
| Monoid (U1 p) | Since: base-4.12.0.0 |
| (Monoid a, Monoid b) => Monoid (a, b) | Since: base-2.1 |
| Monoid a => Monoid (ST s a) | Since: base-4.11.0.0 |
| Ord k => Monoid (Map k v) | |
| (Eq k, Hashable k) => Monoid (HashMap k v) | If a key occurs in both maps, the mapping from the first will be the mapping in the result. Examples
|
| Monoid (Parser i a) | |
| Monoid (Proxy s) | Since: base-4.7.0.0 |
| (Monoid a, Monoid b) => Monoid (Pair a b) | |
| Monoid (f p) => Monoid (Rec1 f p) | Since: base-4.12.0.0 |
| (Monoid a, Monoid b, Monoid c) => Monoid (a, b, c) | Since: base-2.1 |
| Monoid a => Monoid (Const a b) | Since: base-4.9.0.0 |
| (Applicative f, Monoid a) => Monoid (Ap f a) | Since: base-4.12.0.0 |
| Alternative f => Monoid (Alt f a) | Since: base-4.8.0.0 |
| (Semigroup a, Monoid a) => Monoid (Tagged s a) | |
| Monoid c => Monoid (K1 i c p) | Since: base-4.12.0.0 |
| (Monoid (f p), Monoid (g p)) => Monoid ((f :*: g) p) | Since: base-4.12.0.0 |
| (Monoid a, Monoid b, Monoid c, Monoid d) => Monoid (a, b, c, d) | Since: base-2.1 |
| Monoid (f p) => Monoid (M1 i c f p) | Since: base-4.12.0.0 |
| Monoid (f (g p)) => Monoid ((f :.: g) p) | Since: base-4.12.0.0 |
| (Monoid a, Monoid b, Monoid c, Monoid d, Monoid e) => Monoid (a, b, c, d, e) | Since: base-2.1 |
A type that can be converted to JSON.
Instances in general must specify toJSON and should (but don't need
to) specify toEncoding.
An example type and instance:
-- Allow ourselves to writeTextliterals. {-# LANGUAGE OverloadedStrings #-} data Coord = Coord { x :: Double, y :: Double } instanceToJSONCoord wheretoJSON(Coord x y) =object["x".=x, "y".=y]toEncoding(Coord x y) =pairs("x".=x<>"y".=y)
Instead of manually writing your ToJSON instance, there are two options
to do it automatically:
- Data.Aeson.TH provides Template Haskell functions which will derive an instance at compile time. The generated instance is optimized for your type so it will probably be more efficient than the following option.
- The compiler can provide a default generic implementation for
toJSON.
To use the second, simply add a deriving clause to your
datatype and declare a GenericToJSON instance. If you require nothing other than
defaultOptions, it is sufficient to write (and this is the only
alternative where the default toJSON implementation is sufficient):
{-# LANGUAGE DeriveGeneric #-}
import GHC.Generics
data Coord = Coord { x :: Double, y :: Double } deriving Generic
instance ToJSON Coord where
toEncoding = genericToEncoding defaultOptions
If on the other hand you wish to customize the generic decoding, you have to implement both methods:
customOptions =defaultOptions{fieldLabelModifier=maptoUpper} instanceToJSONCoord wheretoJSON=genericToJSONcustomOptionstoEncoding=genericToEncodingcustomOptions
Previous versions of this library only had the toJSON method. Adding
toEncoding had two reasons:
- toEncoding is more efficient for the common case that the output of
toJSONis directly serialized to aByteString. Further, expressing either method in terms of the other would be non-optimal. - The choice of defaults allows a smooth transition for existing users:
Existing instances that do not define
toEncodingstill compile and have the correct semantics. This is ensured by making the default implementation oftoEncodingusetoJSON. This produces correct results, but since it performs an intermediate conversion to aValue, it will be less efficient than directly emitting anEncoding. (this also means that specifying nothing more thaninstance ToJSON Coordwould be sufficient as a generically decoding instance, but there probably exists no good reason to not specifytoEncodingin new instances.)
Minimal complete definition
Nothing
Methods
Convert a Haskell value to a JSON-friendly intermediate type.
toEncoding :: a -> Encoding #
Encode a Haskell value as JSON.
The default implementation of this method creates an
intermediate Value using toJSON. This provides
source-level compatibility for people upgrading from older
versions of this library, but obviously offers no performance
advantage.
To benefit from direct encoding, you must provide an
implementation for this method. The easiest way to do so is by
having your types implement Generic using the DeriveGeneric
extension, and then have GHC generate a method body as follows.
instanceToJSONCoord wheretoEncoding=genericToEncodingdefaultOptions
toJSONList :: [a] -> Value #
toEncodingList :: [a] -> Encoding #
Instances
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 # | |
data ExecutionHint Source #
Constructors
| GlobalOrdinals | |
| Map |
Instances
| Eq ExecutionHint Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: ExecutionHint -> ExecutionHint -> Bool # (/=) :: ExecutionHint -> ExecutionHint -> Bool # | |
| Show ExecutionHint Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> ExecutionHint -> ShowS # show :: ExecutionHint -> String # showList :: [ExecutionHint] -> ShowS # | |
| ToJSON ExecutionHint Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods toJSON :: ExecutionHint -> Value # toEncoding :: ExecutionHint -> Encoding # toJSONList :: [ExecutionHint] -> Value # toEncodingList :: [ExecutionHint] -> Encoding # | |
data CollectionMode Source #
Constructors
| BreadthFirst | |
| DepthFirst |
Instances
| Eq CollectionMode Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: CollectionMode -> CollectionMode -> Bool # (/=) :: CollectionMode -> CollectionMode -> Bool # | |
| Show CollectionMode Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> CollectionMode -> ShowS # show :: CollectionMode -> String # showList :: [CollectionMode] -> ShowS # | |
| ToJSON CollectionMode Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods toJSON :: CollectionMode -> Value # toEncoding :: CollectionMode -> Encoding # toJSONList :: [CollectionMode] -> Value # toEncodingList :: [CollectionMode] -> Encoding # | |
Constructors
| TermOrder | |
Fields | |
data TermInclusion Source #
Constructors
| TermInclusion Text | |
| TermPattern Text Text |
Instances
| Eq TermInclusion Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: TermInclusion -> TermInclusion -> Bool # (/=) :: TermInclusion -> TermInclusion -> Bool # | |
| Show TermInclusion Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> TermInclusion -> ShowS # show :: TermInclusion -> String # showList :: [TermInclusion] -> ShowS # | |
| ToJSON TermInclusion Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods toJSON :: TermInclusion -> Value # toEncoding :: TermInclusion -> Encoding # toJSONList :: [TermInclusion] -> Value # toEncodingList :: [TermInclusion] -> Encoding # | |
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 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 # | |
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 # | |
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 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
newtype SnapshotRepoName Source #
The unique name of a snapshot repository.
Constructors
| SnapshotRepoName | |
Fields | |
Instances
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 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 # | |
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 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 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 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] # | |
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 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 # | |
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 SnapshotName Source #
Constructors
| SnapshotName | |
Fields
| |
Instances
| Eq SnapshotName Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
| Show SnapshotName Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods showsPrec :: Int -> SnapshotName -> ShowS # show :: SnapshotName -> String # showList :: [SnapshotName] -> ShowS # | |
| ToJSON SnapshotName Source # | |
Defined in Database.Bloodhound.Internal.Newtypes Methods toJSON :: SnapshotName -> Value # toEncoding :: SnapshotName -> Encoding # toJSONList :: [SnapshotName] -> Value # toEncodingList :: [SnapshotName] -> Encoding # | |
| FromJSON SnapshotName Source # | |
Defined in Database.Bloodhound.Internal.Newtypes | |
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 # | |
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 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 # | |
data RRGroupRefNum Source #
A group number for regex matching. Only values from 1-9 are
supported. Construct with mkRRGroupRefNum
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 # | |
rrGroupRefNum :: RRGroupRefNum -> Int Source #
mkRRGroupRefNum :: Int -> Maybe RRGroupRefNum Source #
Only allows valid group number references (1-9).
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 # | |
Constructors
| Suggest | |
Fields
| |
data SuggestType Source #
Constructors
| SuggestTypePhraseSuggester PhraseSuggester |
Instances
| Eq SuggestType Source # | |
Defined in Database.Bloodhound.Internal.Suggest | |
| Show SuggestType Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods showsPrec :: Int -> SuggestType -> ShowS # show :: SuggestType -> String # showList :: [SuggestType] -> ShowS # | |
| ToJSON SuggestType Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods toJSON :: SuggestType -> Value # toEncoding :: SuggestType -> Encoding # toJSONList :: [SuggestType] -> Value # toEncodingList :: [SuggestType] -> Encoding # | |
| FromJSON SuggestType Source # | |
Defined in Database.Bloodhound.Internal.Suggest | |
data PhraseSuggester Source #
Constructors
Instances
| Eq PhraseSuggester Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods (==) :: PhraseSuggester -> PhraseSuggester -> Bool # (/=) :: PhraseSuggester -> PhraseSuggester -> Bool # | |
| Show PhraseSuggester Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods showsPrec :: Int -> PhraseSuggester -> ShowS # show :: PhraseSuggester -> String # showList :: [PhraseSuggester] -> ShowS # | |
| ToJSON PhraseSuggester Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods toJSON :: PhraseSuggester -> Value # toEncoding :: PhraseSuggester -> Encoding # toJSONList :: [PhraseSuggester] -> Value # toEncodingList :: [PhraseSuggester] -> Encoding # | |
| FromJSON PhraseSuggester Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods parseJSON :: Value -> Parser PhraseSuggester # parseJSONList :: Value -> Parser [PhraseSuggester] # | |
data PhraseSuggesterHighlighter Source #
Constructors
| PhraseSuggesterHighlighter | |
Instances
data PhraseSuggesterCollate Source #
Constructors
| PhraseSuggesterCollate | |
Instances
| Eq PhraseSuggesterCollate Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods (==) :: PhraseSuggesterCollate -> PhraseSuggesterCollate -> Bool # (/=) :: PhraseSuggesterCollate -> PhraseSuggesterCollate -> Bool # | |
| Show PhraseSuggesterCollate Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods showsPrec :: Int -> PhraseSuggesterCollate -> ShowS # show :: PhraseSuggesterCollate -> String # showList :: [PhraseSuggesterCollate] -> ShowS # | |
| ToJSON PhraseSuggesterCollate Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods toJSON :: PhraseSuggesterCollate -> Value # toEncoding :: PhraseSuggesterCollate -> Encoding # toJSONList :: [PhraseSuggesterCollate] -> Value # | |
| FromJSON PhraseSuggesterCollate Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods parseJSON :: Value -> Parser PhraseSuggesterCollate # parseJSONList :: Value -> Parser [PhraseSuggesterCollate] # | |
data SuggestOptions Source #
Constructors
| SuggestOptions | |
Fields | |
Instances
| Eq SuggestOptions Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods (==) :: SuggestOptions -> SuggestOptions -> Bool # (/=) :: SuggestOptions -> SuggestOptions -> Bool # | |
| Read SuggestOptions Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods readsPrec :: Int -> ReadS SuggestOptions # readList :: ReadS [SuggestOptions] # | |
| Show SuggestOptions Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods showsPrec :: Int -> SuggestOptions -> ShowS # show :: SuggestOptions -> String # showList :: [SuggestOptions] -> ShowS # | |
| FromJSON SuggestOptions Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods parseJSON :: Value -> Parser SuggestOptions # parseJSONList :: Value -> Parser [SuggestOptions] # | |
data SuggestResponse Source #
Constructors
| SuggestResponse | |
Fields | |
Instances
| Eq SuggestResponse Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods (==) :: SuggestResponse -> SuggestResponse -> Bool # (/=) :: SuggestResponse -> SuggestResponse -> Bool # | |
| Read SuggestResponse Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods readsPrec :: Int -> ReadS SuggestResponse # readList :: ReadS [SuggestResponse] # | |
| Show SuggestResponse Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods showsPrec :: Int -> SuggestResponse -> ShowS # show :: SuggestResponse -> String # showList :: [SuggestResponse] -> ShowS # | |
| FromJSON SuggestResponse Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods parseJSON :: Value -> Parser SuggestResponse # parseJSONList :: Value -> Parser [SuggestResponse] # | |
data NamedSuggestionResponse Source #
Constructors
| NamedSuggestionResponse | |
Fields
| |
Instances
| Eq NamedSuggestionResponse Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods (==) :: NamedSuggestionResponse -> NamedSuggestionResponse -> Bool # (/=) :: NamedSuggestionResponse -> NamedSuggestionResponse -> Bool # | |
| Read NamedSuggestionResponse Source # | |
Defined in Database.Bloodhound.Internal.Suggest | |
| Show NamedSuggestionResponse Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods showsPrec :: Int -> NamedSuggestionResponse -> ShowS # show :: NamedSuggestionResponse -> String # showList :: [NamedSuggestionResponse] -> ShowS # | |
| FromJSON NamedSuggestionResponse Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods parseJSON :: Value -> Parser NamedSuggestionResponse # parseJSONList :: Value -> Parser [NamedSuggestionResponse] # | |
data DirectGenerators Source #
Constructors
Instances
| Eq DirectGenerators Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods (==) :: DirectGenerators -> DirectGenerators -> Bool # (/=) :: DirectGenerators -> DirectGenerators -> Bool # | |
| Show DirectGenerators Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods showsPrec :: Int -> DirectGenerators -> ShowS # show :: DirectGenerators -> String # showList :: [DirectGenerators] -> ShowS # | |
| ToJSON DirectGenerators Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods toJSON :: DirectGenerators -> Value # toEncoding :: DirectGenerators -> Encoding # toJSONList :: [DirectGenerators] -> Value # toEncodingList :: [DirectGenerators] -> Encoding # | |
| FromJSON DirectGenerators Source # | |
Defined in Database.Bloodhound.Internal.Suggest Methods parseJSON :: Value -> Parser DirectGenerators # parseJSONList :: Value -> Parser [DirectGenerators] # | |
data DirectGeneratorSuggestModeTypes Source #
Constructors
| DirectGeneratorSuggestModeMissing | |
| DirectGeneratorSuggestModePopular | |
| DirectGeneratorSuggestModeAlways |
Instances
data Aggregation Source #
Constructors
Instances
| Eq Aggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation | |
| Show Aggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> Aggregation -> ShowS # show :: Aggregation -> String # showList :: [Aggregation] -> ShowS # | |
| ToJSON Aggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods toJSON :: Aggregation -> Value # toEncoding :: Aggregation -> Encoding # toJSONList :: [Aggregation] -> Value # toEncodingList :: [Aggregation] -> Encoding # | |
type Aggregations = Map Key Aggregation Source #
data BucketValue Source #
Constructors
| TextValue Text | |
| ScientificValue Scientific | |
| BoolValue Bool |
Instances
| Read BucketValue Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods readsPrec :: Int -> ReadS BucketValue # readList :: ReadS [BucketValue] # readPrec :: ReadPrec BucketValue # readListPrec :: ReadPrec [BucketValue] # | |
| Show BucketValue Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> BucketValue -> ShowS # show :: BucketValue -> String # showList :: [BucketValue] -> ShowS # | |
| FromJSON BucketValue Source # | |
Defined in Database.Bloodhound.Internal.Aggregation | |
class BucketAggregation a where Source #
Instances
| BucketAggregation DateRangeResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods key :: DateRangeResult -> BucketValue Source # docCount :: DateRangeResult -> Int Source # aggs :: DateRangeResult -> Maybe AggregationResults Source # | |
| BucketAggregation DateHistogramResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods key :: DateHistogramResult -> BucketValue Source # docCount :: DateHistogramResult -> Int Source # aggs :: DateHistogramResult -> Maybe AggregationResults Source # | |
| BucketAggregation TermsResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation | |
data TermsAggregation Source #
Constructors
Instances
| Eq TermsAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: TermsAggregation -> TermsAggregation -> Bool # (/=) :: TermsAggregation -> TermsAggregation -> Bool # | |
| Show TermsAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> TermsAggregation -> ShowS # show :: TermsAggregation -> String # showList :: [TermsAggregation] -> ShowS # | |
data MissingAggregation Source #
Constructors
| MissingAggregation | |
Instances
| Eq MissingAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: MissingAggregation -> MissingAggregation -> Bool # (/=) :: MissingAggregation -> MissingAggregation -> Bool # | |
| Show MissingAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> MissingAggregation -> ShowS # show :: MissingAggregation -> String # showList :: [MissingAggregation] -> ShowS # | |
data ValueCountAggregation Source #
See https://www.elastic.co/guide/en/elasticsearch/reference/current/search-aggregations-metrics-valuecount-aggregation.html for more information.
Constructors
| FieldValueCount FieldName | |
| ScriptValueCount Script |
Instances
| Eq ValueCountAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: ValueCountAggregation -> ValueCountAggregation -> Bool # (/=) :: ValueCountAggregation -> ValueCountAggregation -> Bool # | |
| Show ValueCountAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> ValueCountAggregation -> ShowS # show :: ValueCountAggregation -> String # showList :: [ValueCountAggregation] -> ShowS # | |
data FilterAggregation Source #
Single-bucket filter aggregations. See https://www.elastic.co/guide/en/elasticsearch/reference/current/search-aggregations-bucket-filter-aggregation.html#search-aggregations-bucket-filter-aggregation for more information.
Constructors
| FilterAggregation | |
Fields
| |
Instances
| Eq FilterAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: FilterAggregation -> FilterAggregation -> Bool # (/=) :: FilterAggregation -> FilterAggregation -> Bool # | |
| Show FilterAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> FilterAggregation -> ShowS # show :: FilterAggregation -> String # showList :: [FilterAggregation] -> ShowS # | |
data CardinalityAggregation Source #
Constructors
| CardinalityAggregation | |
Fields | |
Instances
| Eq CardinalityAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: CardinalityAggregation -> CardinalityAggregation -> Bool # (/=) :: CardinalityAggregation -> CardinalityAggregation -> Bool # | |
| Show CardinalityAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> CardinalityAggregation -> ShowS # show :: CardinalityAggregation -> String # showList :: [CardinalityAggregation] -> ShowS # | |
data DateHistogramAggregation Source #
Constructors
| DateHistogramAggregation | |
Fields
| |
Instances
| Eq DateHistogramAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: DateHistogramAggregation -> DateHistogramAggregation -> Bool # (/=) :: DateHistogramAggregation -> DateHistogramAggregation -> Bool # | |
| Show DateHistogramAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> DateHistogramAggregation -> ShowS # show :: DateHistogramAggregation -> String # showList :: [DateHistogramAggregation] -> ShowS # | |
data DateRangeAggregation Source #
Constructors
| DateRangeAggregation | |
Instances
| Eq DateRangeAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: DateRangeAggregation -> DateRangeAggregation -> Bool # (/=) :: DateRangeAggregation -> DateRangeAggregation -> Bool # | |
| Show DateRangeAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> DateRangeAggregation -> ShowS # show :: DateRangeAggregation -> String # showList :: [DateRangeAggregation] -> ShowS # | |
| ToJSON DateRangeAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods toJSON :: DateRangeAggregation -> Value # toEncoding :: DateRangeAggregation -> Encoding # toJSONList :: [DateRangeAggregation] -> Value # toEncodingList :: [DateRangeAggregation] -> Encoding # | |
data DateRangeAggRange Source #
Constructors
| DateRangeFrom DateMathExpr | |
| DateRangeTo DateMathExpr | |
| DateRangeFromAndTo DateMathExpr DateMathExpr |
Instances
| Eq DateRangeAggRange Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: DateRangeAggRange -> DateRangeAggRange -> Bool # (/=) :: DateRangeAggRange -> DateRangeAggRange -> Bool # | |
| Show DateRangeAggRange Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> DateRangeAggRange -> ShowS # show :: DateRangeAggRange -> String # showList :: [DateRangeAggRange] -> ShowS # | |
| ToJSON DateRangeAggRange Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods toJSON :: DateRangeAggRange -> Value # toEncoding :: DateRangeAggRange -> Encoding # toJSONList :: [DateRangeAggRange] -> Value # toEncodingList :: [DateRangeAggRange] -> Encoding # | |
data DateMathExpr Source #
See https://www.elastic.co/guide/en/elasticsearch/reference/current/common-options.html#date-math for more information.
Constructors
| DateMathExpr DateMathAnchor [DateMathModifier] |
Instances
| Eq DateMathExpr Source # | |
Defined in Database.Bloodhound.Internal.Aggregation | |
| Show DateMathExpr Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> DateMathExpr -> ShowS # show :: DateMathExpr -> String # showList :: [DateMathExpr] -> ShowS # | |
| ToJSON DateMathExpr Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods toJSON :: DateMathExpr -> Value # toEncoding :: DateMathExpr -> Encoding # toJSONList :: [DateMathExpr] -> Value # toEncodingList :: [DateMathExpr] -> Encoding # | |
data DateMathAnchor Source #
Starting point for a date range. This along with the DateMathModifiers gets you the date ES will start from.
Instances
| Eq DateMathAnchor Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: DateMathAnchor -> DateMathAnchor -> Bool # (/=) :: DateMathAnchor -> DateMathAnchor -> Bool # | |
| Show DateMathAnchor Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> DateMathAnchor -> ShowS # show :: DateMathAnchor -> String # showList :: [DateMathAnchor] -> ShowS # | |
data DateMathModifier Source #
Constructors
| AddTime Int DateMathUnit | |
| SubtractTime Int DateMathUnit | |
| RoundDownTo DateMathUnit |
Instances
| Eq DateMathModifier Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: DateMathModifier -> DateMathModifier -> Bool # (/=) :: DateMathModifier -> DateMathModifier -> Bool # | |
| Show DateMathModifier Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> DateMathModifier -> ShowS # show :: DateMathModifier -> String # showList :: [DateMathModifier] -> ShowS # | |
data DateMathUnit Source #
Instances
| Eq DateMathUnit Source # | |
Defined in Database.Bloodhound.Internal.Aggregation | |
| Show DateMathUnit Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> DateMathUnit -> ShowS # show :: DateMathUnit -> String # showList :: [DateMathUnit] -> ShowS # | |
data TopHitsAggregation Source #
Instances
| Eq TopHitsAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: TopHitsAggregation -> TopHitsAggregation -> Bool # (/=) :: TopHitsAggregation -> TopHitsAggregation -> Bool # | |
| Show TopHitsAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> TopHitsAggregation -> ShowS # show :: TopHitsAggregation -> String # showList :: [TopHitsAggregation] -> ShowS # | |
data StatisticsAggregation Source #
Constructors
| StatisticsAggregation | |
Fields | |
Instances
| Eq StatisticsAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: StatisticsAggregation -> StatisticsAggregation -> Bool # (/=) :: StatisticsAggregation -> StatisticsAggregation -> Bool # | |
| Show StatisticsAggregation Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> StatisticsAggregation -> ShowS # show :: StatisticsAggregation -> String # showList :: [StatisticsAggregation] -> ShowS # | |
type SearchAfterKey = [Value] Source #
newtype CountQuery Source #
Constructors
| CountQuery | |
Fields
| |
Instances
| Eq CountQuery Source # | |
Defined in Database.Bloodhound.Internal.Count | |
| Show CountQuery Source # | |
Defined in Database.Bloodhound.Internal.Count Methods showsPrec :: Int -> CountQuery -> ShowS # show :: CountQuery -> String # showList :: [CountQuery] -> ShowS # | |
| ToJSON CountQuery Source # | |
Defined in Database.Bloodhound.Internal.Count Methods toJSON :: CountQuery -> Value # toEncoding :: CountQuery -> Encoding # toJSONList :: [CountQuery] -> Value # toEncodingList :: [CountQuery] -> Encoding # | |
data CountResponse Source #
Constructors
| CountResponse | |
Fields
| |
Instances
| Eq CountResponse Source # | |
Defined in Database.Bloodhound.Internal.Count Methods (==) :: CountResponse -> CountResponse -> Bool # (/=) :: CountResponse -> CountResponse -> Bool # | |
| Show CountResponse Source # | |
Defined in Database.Bloodhound.Internal.Count Methods showsPrec :: Int -> CountResponse -> ShowS # show :: CountResponse -> String # showList :: [CountResponse] -> ShowS # | |
| FromJSON CountResponse Source # | |
Defined in Database.Bloodhound.Internal.Count Methods parseJSON :: Value -> Parser CountResponse # parseJSONList :: Value -> Parser [CountResponse] # | |
data CountShards Source #
Constructors
| CountShards | |
Instances
| Eq CountShards Source # | |
Defined in Database.Bloodhound.Internal.Count | |
| Show CountShards Source # | |
Defined in Database.Bloodhound.Internal.Count Methods showsPrec :: Int -> CountShards -> ShowS # show :: CountShards -> String # showList :: [CountShards] -> ShowS # | |
| FromJSON CountShards Source # | |
Defined in Database.Bloodhound.Internal.Count | |
data Highlights Source #
Constructors
| Highlights | |
Fields | |
Instances
| Eq Highlights Source # | |
Defined in Database.Bloodhound.Internal.Highlight | |
| Show Highlights Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods showsPrec :: Int -> Highlights -> ShowS # show :: Highlights -> String # showList :: [Highlights] -> ShowS # | |
| ToJSON Highlights Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods toJSON :: Highlights -> Value # toEncoding :: Highlights -> Encoding # toJSONList :: [Highlights] -> Value # toEncodingList :: [Highlights] -> Encoding # | |
data FieldHighlight Source #
Constructors
| FieldHighlight FieldName (Maybe HighlightSettings) |
Instances
| Eq FieldHighlight Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods (==) :: FieldHighlight -> FieldHighlight -> Bool # (/=) :: FieldHighlight -> FieldHighlight -> Bool # | |
| Show FieldHighlight Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods showsPrec :: Int -> FieldHighlight -> ShowS # show :: FieldHighlight -> String # showList :: [FieldHighlight] -> ShowS # | |
| ToJSON FieldHighlight Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods toJSON :: FieldHighlight -> Value # toEncoding :: FieldHighlight -> Encoding # toJSONList :: [FieldHighlight] -> Value # toEncodingList :: [FieldHighlight] -> Encoding # | |
data HighlightSettings Source #
Instances
| Eq HighlightSettings Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods (==) :: HighlightSettings -> HighlightSettings -> Bool # (/=) :: HighlightSettings -> HighlightSettings -> Bool # | |
| Show HighlightSettings Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods showsPrec :: Int -> HighlightSettings -> ShowS # show :: HighlightSettings -> String # showList :: [HighlightSettings] -> ShowS # | |
| ToJSON HighlightSettings Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods toJSON :: HighlightSettings -> Value # toEncoding :: HighlightSettings -> Encoding # toJSONList :: [HighlightSettings] -> Value # toEncodingList :: [HighlightSettings] -> Encoding # | |
data PlainHighlight Source #
Constructors
| PlainHighlight | |
Fields | |
Instances
| Eq PlainHighlight Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods (==) :: PlainHighlight -> PlainHighlight -> Bool # (/=) :: PlainHighlight -> PlainHighlight -> Bool # | |
| Show PlainHighlight Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods showsPrec :: Int -> PlainHighlight -> ShowS # show :: PlainHighlight -> String # showList :: [PlainHighlight] -> ShowS # | |
data PostingsHighlight Source #
Constructors
| PostingsHighlight (Maybe CommonHighlight) |
Instances
| Eq PostingsHighlight Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods (==) :: PostingsHighlight -> PostingsHighlight -> Bool # (/=) :: PostingsHighlight -> PostingsHighlight -> Bool # | |
| Show PostingsHighlight Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods showsPrec :: Int -> PostingsHighlight -> ShowS # show :: PostingsHighlight -> String # showList :: [PostingsHighlight] -> ShowS # | |
data FastVectorHighlight Source #
Constructors
| FastVectorHighlight | |
Fields
| |
Instances
| Eq FastVectorHighlight Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods (==) :: FastVectorHighlight -> FastVectorHighlight -> Bool # (/=) :: FastVectorHighlight -> FastVectorHighlight -> Bool # | |
| Show FastVectorHighlight Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods showsPrec :: Int -> FastVectorHighlight -> ShowS # show :: FastVectorHighlight -> String # showList :: [FastVectorHighlight] -> ShowS # | |
data CommonHighlight Source #
Constructors
| CommonHighlight | |
Fields
| |
Instances
| Eq CommonHighlight Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods (==) :: CommonHighlight -> CommonHighlight -> Bool # (/=) :: CommonHighlight -> CommonHighlight -> Bool # | |
| Show CommonHighlight Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods showsPrec :: Int -> CommonHighlight -> ShowS # show :: CommonHighlight -> String # showList :: [CommonHighlight] -> ShowS # | |
data NonPostings Source #
Constructors
| NonPostings | |
Fields | |
Instances
| Eq NonPostings Source # | |
Defined in Database.Bloodhound.Internal.Highlight | |
| Show NonPostings Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods showsPrec :: Int -> NonPostings -> ShowS # show :: NonPostings -> String # showList :: [NonPostings] -> ShowS # | |
data HighlightEncoder Source #
Constructors
| DefaultEncoder | |
| HTMLEncoder |
Instances
| Eq HighlightEncoder Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods (==) :: HighlightEncoder -> HighlightEncoder -> Bool # (/=) :: HighlightEncoder -> HighlightEncoder -> Bool # | |
| Show HighlightEncoder Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods showsPrec :: Int -> HighlightEncoder -> ShowS # show :: HighlightEncoder -> String # showList :: [HighlightEncoder] -> ShowS # | |
| ToJSON HighlightEncoder Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods toJSON :: HighlightEncoder -> Value # toEncoding :: HighlightEncoder -> Encoding # toJSONList :: [HighlightEncoder] -> Value # toEncodingList :: [HighlightEncoder] -> Encoding # | |
data HighlightTag Source #
Constructors
| TagSchema Text | |
| CustomTags ([Text], [Text]) |
Instances
| Eq HighlightTag Source # | |
Defined in Database.Bloodhound.Internal.Highlight | |
| Show HighlightTag Source # | |
Defined in Database.Bloodhound.Internal.Highlight Methods showsPrec :: Int -> HighlightTag -> ShowS # show :: HighlightTag -> String # showList :: [HighlightTag] -> ShowS # | |
data MissingResult Source #
Constructors
| MissingResult | |
Fields | |
Instances
| Show MissingResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> MissingResult -> ShowS # show :: MissingResult -> String # showList :: [MissingResult] -> ShowS # | |
| FromJSON MissingResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods parseJSON :: Value -> Parser MissingResult # parseJSONList :: Value -> Parser [MissingResult] # | |
data TermsResult Source #
Constructors
| TermsResult | |
Fields | |
Instances
| Read TermsResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods readsPrec :: Int -> ReadS TermsResult # readList :: ReadS [TermsResult] # readPrec :: ReadPrec TermsResult # readListPrec :: ReadPrec [TermsResult] # | |
| Show TermsResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> TermsResult -> ShowS # show :: TermsResult -> String # showList :: [TermsResult] -> ShowS # | |
| FromJSON TermsResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation | |
| BucketAggregation TermsResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation | |
data DateHistogramResult Source #
Constructors
| DateHistogramResult | |
Fields
| |
Instances
| Show DateHistogramResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> DateHistogramResult -> ShowS # show :: DateHistogramResult -> String # showList :: [DateHistogramResult] -> ShowS # | |
| FromJSON DateHistogramResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods parseJSON :: Value -> Parser DateHistogramResult # parseJSONList :: Value -> Parser [DateHistogramResult] # | |
| BucketAggregation DateHistogramResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods key :: DateHistogramResult -> BucketValue Source # docCount :: DateHistogramResult -> Int Source # aggs :: DateHistogramResult -> Maybe AggregationResults Source # | |
data DateRangeResult Source #
Constructors
| DateRangeResult | |
Fields | |
Instances
| Eq DateRangeResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: DateRangeResult -> DateRangeResult -> Bool # (/=) :: DateRangeResult -> DateRangeResult -> Bool # | |
| Show DateRangeResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> DateRangeResult -> ShowS # show :: DateRangeResult -> String # showList :: [DateRangeResult] -> ShowS # | |
| FromJSON DateRangeResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods parseJSON :: Value -> Parser DateRangeResult # parseJSONList :: Value -> Parser [DateRangeResult] # | |
| BucketAggregation DateRangeResult Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods key :: DateRangeResult -> BucketValue Source # docCount :: DateRangeResult -> Int Source # aggs :: DateRangeResult -> Maybe AggregationResults Source # | |
data TopHitResult a Source #
Constructors
| TopHitResult | |
Fields
| |
Instances
| Eq a => Eq (TopHitResult a) Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods (==) :: TopHitResult a -> TopHitResult a -> Bool # (/=) :: TopHitResult a -> TopHitResult a -> Bool # | |
| Show a => Show (TopHitResult a) Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods showsPrec :: Int -> TopHitResult a -> ShowS # show :: TopHitResult a -> String # showList :: [TopHitResult a] -> ShowS # | |
| FromJSON a => FromJSON (TopHitResult a) Source # | |
Defined in Database.Bloodhound.Internal.Aggregation Methods parseJSON :: Value -> Parser (TopHitResult a) # parseJSONList :: Value -> Parser [TopHitResult a] # | |
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 # | |
Constructors
| Analysis | |
data AnalyzerDefinition Source #
Constructors
| AnalyzerDefinition | |
Instances
| Eq AnalyzerDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods (==) :: AnalyzerDefinition -> AnalyzerDefinition -> Bool # (/=) :: AnalyzerDefinition -> AnalyzerDefinition -> Bool # | |
| Show AnalyzerDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods showsPrec :: Int -> AnalyzerDefinition -> ShowS # show :: AnalyzerDefinition -> String # showList :: [AnalyzerDefinition] -> ShowS # | |
| ToJSON AnalyzerDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods toJSON :: AnalyzerDefinition -> Value # toEncoding :: AnalyzerDefinition -> Encoding # toJSONList :: [AnalyzerDefinition] -> Value # toEncodingList :: [AnalyzerDefinition] -> Encoding # | |
| FromJSON AnalyzerDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods parseJSON :: Value -> Parser AnalyzerDefinition # parseJSONList :: Value -> Parser [AnalyzerDefinition] # | |
newtype TokenizerDefinition Source #
Constructors
| TokenizerDefinitionNgram Ngram |
Instances
| Eq TokenizerDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods (==) :: TokenizerDefinition -> TokenizerDefinition -> Bool # (/=) :: TokenizerDefinition -> TokenizerDefinition -> Bool # | |
| Show TokenizerDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods showsPrec :: Int -> TokenizerDefinition -> ShowS # show :: TokenizerDefinition -> String # showList :: [TokenizerDefinition] -> ShowS # | |
| ToJSON TokenizerDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods toJSON :: TokenizerDefinition -> Value # toEncoding :: TokenizerDefinition -> Encoding # toJSONList :: [TokenizerDefinition] -> Value # toEncodingList :: [TokenizerDefinition] -> Encoding # | |
| FromJSON TokenizerDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods parseJSON :: Value -> Parser TokenizerDefinition # parseJSONList :: Value -> Parser [TokenizerDefinition] # | |
data TokenFilterDefinition Source #
Token filters are used to create custom analyzers.
Constructors
Instances
| Eq TokenFilterDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods (==) :: TokenFilterDefinition -> TokenFilterDefinition -> Bool # (/=) :: TokenFilterDefinition -> TokenFilterDefinition -> Bool # | |
| Show TokenFilterDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods showsPrec :: Int -> TokenFilterDefinition -> ShowS # show :: TokenFilterDefinition -> String # showList :: [TokenFilterDefinition] -> ShowS # | |
| ToJSON TokenFilterDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods toJSON :: TokenFilterDefinition -> Value # toEncoding :: TokenFilterDefinition -> Encoding # toJSONList :: [TokenFilterDefinition] -> Value # toEncodingList :: [TokenFilterDefinition] -> Encoding # | |
| FromJSON TokenFilterDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods parseJSON :: Value -> Parser TokenFilterDefinition # parseJSONList :: Value -> Parser [TokenFilterDefinition] # | |
data CharFilterDefinition Source #
Character filters are used to preprocess the stream of characters before it is passed to the tokenizer.
Constructors
| CharFilterDefinitionMapping (Map Text Text) | |
| CharFilterDefinitionPatternReplace | |
Instances
| Eq CharFilterDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods (==) :: CharFilterDefinition -> CharFilterDefinition -> Bool # (/=) :: CharFilterDefinition -> CharFilterDefinition -> Bool # | |
| Show CharFilterDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods showsPrec :: Int -> CharFilterDefinition -> ShowS # show :: CharFilterDefinition -> String # showList :: [CharFilterDefinition] -> ShowS # | |
| ToJSON CharFilterDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods toJSON :: CharFilterDefinition -> Value # toEncoding :: CharFilterDefinition -> Encoding # toJSONList :: [CharFilterDefinition] -> Value # toEncodingList :: [CharFilterDefinition] -> Encoding # | |
| FromJSON CharFilterDefinition Source # | |
Defined in Database.Bloodhound.Internal.Analysis Methods parseJSON :: Value -> Parser CharFilterDefinition # parseJSONList :: Value -> Parser [CharFilterDefinition] # | |
Constructors
| Ngram | |
Fields
| |
Constructors
| TokenLetter | |
| TokenDigit | |
| TokenWhitespace | |
| TokenPunctuation | |
| TokenSymbol |
The set of languages that can be passed to various analyzers,
filters, etc. in Elasticsearch. Most data types in this module
that have a Language field are actually only actually to
handle a subset of these languages. Consult the official
Elasticsearch documentation to see what is actually supported.
Constructors