lunr.js 0.7.2

lunr

Convenience function for instantiating a new lunr index and configuring it with the default pipeline functions and the passed config function.

When using this convenience function a new index will be created with the following functions already in the pipeline:

lunr.StopWordFilter - filters out any stop words before they enter the index

lunr.stemmer - stems the tokens before entering the index.

Example:

var idx = lunr(function () {
  this.field('title', 10)
  this.field('tags', 100)
  this.field('body')

  this.ref('cid')

  this.pipeline.add(function () {
    // some custom pipeline function
  })

})

EventEmitter

lunr.EventEmitter is an event emitter for lunr. It manages adding and removing event handlers and triggering events and their handlers.

addListener

lunr.EventEmitter.prototype.addListener()

method

Params

  • [eventName] - The name(s) of events to bind this function to.
  • fn - The function to call when an event is fired.

Binds a handler function to a specific event(s).

Can bind a single function to many different events in one call.

Source

lunr.EventEmitter.prototype.addListener = function () {
  var args = Array.prototype.slice.call(arguments),
      fn = args.pop(),
      names = args

  if (typeof fn !== "function") throw new TypeError ("last argument must be a function")

  names.forEach(function (name) {
    if (!this.hasHandler(name)) this.events[name] = []
    this.events[name].push(fn)
  }, this)
}

removeListener

lunr.EventEmitter.prototype.removeListener()

method

Params

  • eventName - The name of the event to remove this function from.
  • fn - The function to remove from an event.

Removes a handler function from a specific event.

Source

lunr.EventEmitter.prototype.removeListener = function (name, fn) {
  if (!this.hasHandler(name)) return

  var fnIndex = this.events[name].indexOf(fn)
  this.events[name].splice(fnIndex, 1)

  if (!this.events[name].length) delete this.events[name]
}

emit

lunr.EventEmitter.prototype.emit()

method

Params

  • eventName - The name of the event to emit.

Calls all functions bound to the given event.

Additional data can be passed to the event handler as arguments to emit after the event name.

Source

lunr.EventEmitter.prototype.emit = function (name) {
  if (!this.hasHandler(name)) return

  var args = Array.prototype.slice.call(arguments, 1)

  this.events[name].forEach(function (fn) {
    fn.apply(undefined, args)
  })
}

hasHandler

lunr.EventEmitter.prototype.hasHandler()

method

Params

  • eventName - The name of the event to check.

Checks whether a handler has ever been stored against an event.

Source

lunr.EventEmitter.prototype.hasHandler = function (name) {
  return name in this.events
}

tokenizer

A function for splitting a string into tokens ready to be inserted into the search index. Uses lunr.tokenizer.separator to split strings, change the value of this property to change how strings are split into tokens.

load

lunr.tokenizer.load()

method

Params

  • label - The label of the serialised tokenizer.

Loads a previously serialised tokenizer.

A tokenizer function to be loaded must already be registered with lunr.tokenizer. If the serialised tokenizer has not been registered then an error will be thrown.

Source

lunr.tokenizer.load = function (label) {
  var fn = this.registeredFunctions[label]

  if (!fn) {
    throw new Error('Cannot load un-registered function: ' + label)
  }

  return fn
}

lunr.tokenizer.label = 'default'

lunr.tokenizer.registeredFunctions = {
  'default': lunr.tokenizer
}

registerFunction

lunr.tokenizer.registerFunction()

method

Params

  • fn - The function to register.
  • label - The label to register this function with

Register a tokenizer function.

Functions that are used as tokenizers should be registered if they are to be used with a serialised index.

Registering a function does not add it to an index, functions must still be associated with a specific index for them to be used when indexing and searching documents.

Source

lunr.tokenizer.registerFunction = function (fn, label) {
  if (label in this.registeredFunctions) {
    lunr.utils.warn('Overwriting existing tokenizer: ' + label)
  }

  fn.label = label
  this.registeredFunctions[label] = fn
}

Pipeline

lunr.Pipelines maintain an ordered list of functions to be applied to all tokens in documents entering the search index and queries being ran against the index.

An instance of lunr.Index created with the lunr shortcut will contain a pipeline with a stop word filter and an English language stemmer. Extra functions can be added before or after either of these functions or these default functions can be removed.

When run the pipeline will call each function in turn, passing a token, the index of that token in the original list of all tokens and finally a list of all the original tokens.

The output of functions in the pipeline will be passed to the next function in the pipeline. To exclude a token from entering the index the function should return undefined, the rest of the pipeline will not be called with this token.

For serialisation of pipelines to work, all functions used in an instance of a pipeline should be registered with lunr.Pipeline. Registered functions can then be loaded. If trying to load a serialised pipeline that uses functions that are not registered an error will be thrown.

If not planning on serialising the pipeline then registering pipeline functions is not necessary.

registerFunction

lunr.Pipeline.registerFunction()

method

Params

  • fn - The function to check for.
  • label - The label to register this function with

Register a function with the pipeline.

Functions that are used in the pipeline should be registered if the pipeline needs to be serialised, or a serialised pipeline needs to be loaded.

Registering a function does not add it to a pipeline, functions must still be added to instances of the pipeline for them to be used when running a pipeline.

Source

lunr.Pipeline.registerFunction = function (fn, label) {
  if (label in this.registeredFunctions) {
    lunr.utils.warn('Overwriting existing registered function: ' + label)
  }

  fn.label = label
  lunr.Pipeline.registeredFunctions[fn.label] = fn
}

warnIfFunctionNotRegistered

lunr.Pipeline.warnIfFunctionNotRegistered()

method

Params

  • fn - The function to check for.

Warns if the function is not registered as a Pipeline function.

Source

lunr.Pipeline.warnIfFunctionNotRegistered = function (fn) {
  var isRegistered = fn.label && (fn.label in this.registeredFunctions)

  if (!isRegistered) {
    lunr.utils.warn('Function is not registered with pipeline. This may cause problems when serialising the index.\n', fn)
  }
}

load

lunr.Pipeline.load()

method

Params

  • serialised - The serialised pipeline to load.

Loads a previously serialised pipeline.

All functions to be loaded must already be registered with lunr.Pipeline. If any function from the serialised data has not been registered then an error will be thrown.

Source

lunr.Pipeline.load = function (serialised) {
  var pipeline = new lunr.Pipeline

  serialised.forEach(function (fnName) {
    var fn = lunr.Pipeline.registeredFunctions[fnName]

    if (fn) {
      pipeline.add(fn)
    } else {
      throw new Error('Cannot load un-registered function: ' + fnName)
    }
  })

  return pipeline
}

add

lunr.Pipeline.prototype.add()

method

Params

  • functions - Any number of functions to add to the pipeline.

Adds new functions to the end of the pipeline.

Logs a warning if the function has not been registered.

Source

lunr.Pipeline.prototype.add = function () {
  var fns = Array.prototype.slice.call(arguments)

  fns.forEach(function (fn) {
    lunr.Pipeline.warnIfFunctionNotRegistered(fn)
    this._stack.push(fn)
  }, this)
}

after

lunr.Pipeline.prototype.after()

method

Params

  • existingFn - A function that already exists in the pipeline.
  • newFn - The new function to add to the pipeline.

Adds a single function after a function that already exists in the pipeline.

Logs a warning if the function has not been registered.

Source

lunr.Pipeline.prototype.after = function (existingFn, newFn) {
  lunr.Pipeline.warnIfFunctionNotRegistered(newFn)

  var pos = this._stack.indexOf(existingFn)
  if (pos == -1) {
    throw new Error('Cannot find existingFn')
  }

  pos = pos + 1
  this._stack.splice(pos, 0, newFn)
}

before

lunr.Pipeline.prototype.before()

method

Params

  • existingFn - A function that already exists in the pipeline.
  • newFn - The new function to add to the pipeline.

Adds a single function before a function that already exists in the pipeline.

Logs a warning if the function has not been registered.

Source

lunr.Pipeline.prototype.before = function (existingFn, newFn) {
  lunr.Pipeline.warnIfFunctionNotRegistered(newFn)

  var pos = this._stack.indexOf(existingFn)
  if (pos == -1) {
    throw new Error('Cannot find existingFn')
  }

  this._stack.splice(pos, 0, newFn)
}

remove

lunr.Pipeline.prototype.remove()

method

Params

  • fn - The function to remove from the pipeline.

Removes a function from the pipeline.

Source

lunr.Pipeline.prototype.remove = function (fn) {
  var pos = this._stack.indexOf(fn)
  if (pos == -1) {
    return
  }

  this._stack.splice(pos, 1)
}

run

lunr.Pipeline.prototype.run()

method

Params

  • tokens - The tokens to run through the pipeline.

Runs the current list of functions that make up the pipeline against the passed tokens.

Source

lunr.Pipeline.prototype.run = function (tokens) {
  var out = [],
      tokenLength = tokens.length,
      stackLength = this._stack.length

  for (var i = 0; i < tokenLength; i++) {
    var token = tokens[i]

    for (var j = 0; j < stackLength; j++) {
      token = this._stack[j](token, i, tokens)
      if (token === void 0 || token === '') break
    };

    if (token !== void 0 && token !== '') out.push(token)
  };

  return out
}

reset

lunr.Pipeline.prototype.reset()

method

Resets the pipeline by removing any existing processors.

Source

lunr.Pipeline.prototype.reset = function () {
  this._stack = []
}

toJSON

lunr.Pipeline.prototype.toJSON()

method

Returns a representation of the pipeline ready for serialisation.

Logs a warning if the function has not been registered.

Source

lunr.Pipeline.prototype.toJSON = function () {
  return this._stack.map(function (fn) {
    lunr.Pipeline.warnIfFunctionNotRegistered(fn)

    return fn.label
  })
}

Vector

lunr.Vectors implement vector related operations for a series of elements.

Node

lunr.Vector.Node()

method

Params

  • The - index of the node in the vector.
  • The - data at this node in the vector.
  • The - node directly after this node in the vector.

lunr.Vector.Node is a simple struct for each node in a lunr.Vector.

Source

lunr.Vector.Node = function (idx, val, next) {
  this.idx = idx
  this.val = val
  this.next = next
}

magnitude

lunr.Vector.prototype.magnitude()

method

Calculates the magnitude of this vector.

Source

lunr.Vector.prototype.magnitude = function () {
  if (this._magnitude) return this._magnitude
  var node = this.list,
      sumOfSquares = 0,
      val

  while (node) {
    val = node.val
    sumOfSquares += val * val
    node = node.next
  }

  return this._magnitude = Math.sqrt(sumOfSquares)
}

dot

lunr.Vector.prototype.dot()

method

Params

  • otherVector - The vector to compute the dot product with.

Calculates the dot product of this vector and another vector.

Source

lunr.Vector.prototype.dot = function (otherVector) {
  var node = this.list,
      otherNode = otherVector.list,
      dotProduct = 0

  while (node && otherNode) {
    if (node.idx < otherNode.idx) {
      node = node.next
    } else if (node.idx > otherNode.idx) {
      otherNode = otherNode.next
    } else {
      dotProduct += node.val * otherNode.val
      node = node.next
      otherNode = otherNode.next
    }
  }

  return dotProduct
}

similarity

lunr.Vector.prototype.similarity()

method

Params

  • otherVector - The other vector to calculate the

Calculates the cosine similarity between this vector and another vector.

Source

lunr.Vector.prototype.similarity = function (otherVector) {
  return this.dot(otherVector) / (this.magnitude() * otherVector.magnitude())
}

Node

lunr.Vector.Node is a simple struct for each node in a lunr.Vector.

SortedSet

lunr.SortedSets are used to maintain an array of uniq values in a sorted order.

load

lunr.SortedSet.load()

method

Params

  • serialisedData - The serialised set to load.

Loads a previously serialised sorted set.

Source

lunr.SortedSet.load = function (serialisedData) {
  var set = new this

  set.elements = serialisedData
  set.length = serialisedData.length

  return set
}

add

lunr.SortedSet.prototype.add()

method

Params

  • The - objects to add to this set.

Inserts new items into the set in the correct position to maintain the order.

Source

lunr.SortedSet.prototype.add = function () {
  var i, element

  for (i = 0; i < arguments.length; i++) {
    element = arguments[i]
    if (~this.indexOf(element)) continue
    this.elements.splice(this.locationFor(element), 0, element)
  }

  this.length = this.elements.length
}

toArray

lunr.SortedSet.prototype.toArray()

method

Converts this sorted set into an array.

Source

lunr.SortedSet.prototype.toArray = function () {
  return this.elements.slice()
}

map

lunr.SortedSet.prototype.map()

method

Params

  • fn - The function that is called on each element of the
  • ctx - An optional object that can be used as the context

Creates a new array with the results of calling a provided function on every element in this sorted set.

Delegates to Array.prototype.map and has the same signature.

Source

lunr.SortedSet.prototype.map = function (fn, ctx) {
  return this.elements.map(fn, ctx)
}

forEach

lunr.SortedSet.prototype.forEach()

method

Params

  • fn - The function that is called on each element of the
  • ctx - An optional object that can be used as the context

Executes a provided function once per sorted set element.

Delegates to Array.prototype.forEach and has the same signature.

Source

lunr.SortedSet.prototype.forEach = function (fn, ctx) {
  return this.elements.forEach(fn, ctx)
}

indexOf

lunr.SortedSet.prototype.indexOf()

method

Params

  • elem - The object to locate in the sorted set.

Returns the index at which a given element can be found in the sorted set, or -1 if it is not present.

Source

lunr.SortedSet.prototype.indexOf = function (elem) {
  var start = 0,
      end = this.elements.length,
      sectionLength = end - start,
      pivot = start + Math.floor(sectionLength / 2),
      pivotElem = this.elements[pivot]

  while (sectionLength > 1) {
    if (pivotElem === elem) return pivot

    if (pivotElem < elem) start = pivot
    if (pivotElem > elem) end = pivot

    sectionLength = end - start
    pivot = start + Math.floor(sectionLength / 2)
    pivotElem = this.elements[pivot]
  }

  if (pivotElem === elem) return pivot

  return -1
}

locationFor

lunr.SortedSet.prototype.locationFor()

method

Params

  • elem - The elem to find the position for in the set

Returns the position within the sorted set that an element should be inserted at to maintain the current order of the set.

This function assumes that the element to search for does not already exist in the sorted set.

Source

lunr.SortedSet.prototype.locationFor = function (elem) {
  var start = 0,
      end = this.elements.length,
      sectionLength = end - start,
      pivot = start + Math.floor(sectionLength / 2),
      pivotElem = this.elements[pivot]

  while (sectionLength > 1) {
    if (pivotElem < elem) start = pivot
    if (pivotElem > elem) end = pivot

    sectionLength = end - start
    pivot = start + Math.floor(sectionLength / 2)
    pivotElem = this.elements[pivot]
  }

  if (pivotElem > elem) return pivot
  if (pivotElem < elem) return pivot + 1
}

intersect

lunr.SortedSet.prototype.intersect()

method

Params

  • otherSet - The set to intersect with this set.

Creates a new lunr.SortedSet that contains the elements in the intersection of this set and the passed set.

Source

lunr.SortedSet.prototype.intersect = function (otherSet) {
  var intersectSet = new lunr.SortedSet,
      i = 0, j = 0,
      a_len = this.length, b_len = otherSet.length,
      a = this.elements, b = otherSet.elements

  while (true) {
    if (i > a_len - 1 || j > b_len - 1) break

    if (a[i] === b[j]) {
      intersectSet.add(a[i])
      i++, j++
      continue
    }

    if (a[i] < b[j]) {
      i++
      continue
    }

    if (a[i] > b[j]) {
      j++
      continue
    }
  };

  return intersectSet
}

clone

lunr.SortedSet.prototype.clone()

method

Makes a copy of this set

Source

lunr.SortedSet.prototype.clone = function () {
  var clone = new lunr.SortedSet

  clone.elements = this.toArray()
  clone.length = clone.elements.length

  return clone
}

union

lunr.SortedSet.prototype.union()

method

Params

  • otherSet - The set to union with this set.

Creates a new lunr.SortedSet that contains the elements in the union of this set and the passed set.

Source

lunr.SortedSet.prototype.union = function (otherSet) {
  var longSet, shortSet, unionSet

  if (this.length >= otherSet.length) {
    longSet = this, shortSet = otherSet
  } else {
    longSet = otherSet, shortSet = this
  }

  unionSet = longSet.clone()

  for(var i = 0, shortSetElements = shortSet.toArray(); i < shortSetElements.length; i++){
    unionSet.add(shortSetElements[i])
  }

  return unionSet
}

toJSON

lunr.SortedSet.prototype.toJSON()

method

Returns a representation of the sorted set ready for serialisation.

Source

lunr.SortedSet.prototype.toJSON = function () {
  return this.toArray()
}

Index

lunr.Index is object that manages a search index. It contains the indexes and stores all the tokens and document lookups. It also provides the main user facing API for the library.

on

lunr.Index.prototype.on()

method

Params

  • [eventName] - The name(s) of events to bind the function to.
  • fn - The serialised set to load.

Bind a handler to events being emitted by the index.

The handler can be bound to many events at the same time.

Source

lunr.Index.prototype.on = function () {
  var args = Array.prototype.slice.call(arguments)
  return this.eventEmitter.addListener.apply(this.eventEmitter, args)
}

off

lunr.Index.prototype.off()

method

Params

  • eventName - The name of events to remove the function from.
  • fn - The serialised set to load.

Removes a handler from an event being emitted by the index.

Source

lunr.Index.prototype.off = function (name, fn) {
  return this.eventEmitter.removeListener(name, fn)
}

load

lunr.Index.load()

method

Params

  • serialisedData - The serialised set to load.

Loads a previously serialised index.

Issues a warning if the index being imported was serialised by a different version of lunr.

Source

lunr.Index.load = function (serialisedData) {
  if (serialisedData.version !== lunr.version) {
    lunr.utils.warn('version mismatch: current ' + lunr.version + ' importing ' + serialisedData.version)
  }

  var idx = new this

  idx._fields = serialisedData.fields
  idx._ref = serialisedData.ref

  idx.tokenizer(lunr.tokenizer.load(serialisedData.tokenizer))
  idx.documentStore = lunr.Store.load(serialisedData.documentStore)
  idx.tokenStore = lunr.TokenStore.load(serialisedData.tokenStore)
  idx.corpusTokens = lunr.SortedSet.load(serialisedData.corpusTokens)
  idx.pipeline = lunr.Pipeline.load(serialisedData.pipeline)

  return idx
}

field

lunr.Index.prototype.field()

method

Params

  • fieldName - The name of the field within the document that
  • boost - An optional boost that can be applied to terms in this

Adds a field to the list of fields that will be searchable within documents in the index.

An optional boost param can be passed to affect how much tokens in this field rank in search results, by default the boost value is 1.

Fields should be added before any documents are added to the index, fields that are added after documents are added to the index will only apply to new documents added to the index.

Source

lunr.Index.prototype.field = function (fieldName, opts) {
  var opts = opts || {},
      field = { name: fieldName, boost: opts.boost || 1 }

  this._fields.push(field)
  return this
}

ref

lunr.Index.prototype.ref()

method

Params

  • refName - The property to use to uniquely identify the
  • emitEvent - Whether to emit add events, defaults to true

Sets the property used to uniquely identify documents added to the index, by default this property is 'id'.

This should only be changed before adding documents to the index, changing the ref property without resetting the index can lead to unexpected results.

The value of ref can be of any type but it must be stably comparable and orderable.

Source

lunr.Index.prototype.ref = function (refName) {
  this._ref = refName
  return this
}

tokenizer

lunr.Index.prototype.tokenizer()

method

Params

  • fn - The function to use as a tokenizer.

Sets the tokenizer used for this index.

By default the index will use the default tokenizer, lunr.tokenizer. The tokenizer should only be changed before adding documents to the index. Changing the tokenizer without re-building the index can lead to unexpected results.

Source

lunr.Index.prototype.tokenizer = function (fn) {
  var isRegistered = fn.label && (fn.label in lunr.tokenizer.registeredFunctions)

  if (!isRegistered) {
    lunr.utils.warn('Function is not a registered tokenizer. This may cause problems when serialising the index')
  }

  this.tokenizerFn = fn
  return this
}

add

lunr.Index.prototype.add()

method

Params

  • doc - The document to add to the index.
  • emitEvent - Whether or not to emit events, default true.

Add a document to the index.

This is the way new documents enter the index, this function will run the fields from the document through the index's pipeline and then add it to the index, it will then show up in search results.

An 'add' event is emitted with the document that has been added and the index the document has been added to. This event can be silenced by passing false as the second argument to add.

Source

lunr.Index.prototype.add = function (doc, emitEvent) {
  var docTokens = {},
      allDocumentTokens = new lunr.SortedSet,
      docRef = doc[this._ref],
      emitEvent = emitEvent === undefined ? true : emitEvent

  this._fields.forEach(function (field) {
    var fieldTokens = this.pipeline.run(this.tokenizerFn(doc[field.name]))

    docTokens[field.name] = fieldTokens

    for (var i = 0; i < fieldTokens.length; i++) {
      var token = fieldTokens[i]
      allDocumentTokens.add(token)
      this.corpusTokens.add(token)
    }
  }, this)

  this.documentStore.set(docRef, allDocumentTokens)

  for (var i = 0; i < allDocumentTokens.length; i++) {
    var token = allDocumentTokens.elements[i]
    var tf = 0;

    for (var j = 0; j < this._fields.length; j++){
      var field = this._fields[j]
      var fieldTokens = docTokens[field.name]
      var fieldLength = fieldTokens.length

      if (!fieldLength) continue

      var tokenCount = 0
      for (var k = 0; k < fieldLength; k++){
        if (fieldTokens[k] === token){
          tokenCount++
        }
      }

      tf += (tokenCount / fieldLength * field.boost)
    }

    this.tokenStore.add(token, { ref: docRef, tf: tf })
  };

  if (emitEvent) this.eventEmitter.emit('add', doc, this)
}

remove

lunr.Index.prototype.remove()

method

Params

  • doc - The document to remove from the index.
  • emitEvent - Whether to emit remove events, defaults to true

Removes a document from the index.

To make sure documents no longer show up in search results they can be removed from the index using this method.

The document passed only needs to have the same ref property value as the document that was added to the index, they could be completely different objects.

A 'remove' event is emitted with the document that has been removed and the index the document has been removed from. This event can be silenced by passing false as the second argument to remove.

Source

lunr.Index.prototype.remove = function (doc, emitEvent) {
  var docRef = doc[this._ref],
      emitEvent = emitEvent === undefined ? true : emitEvent

  if (!this.documentStore.has(docRef)) return

  var docTokens = this.documentStore.get(docRef)

  this.documentStore.remove(docRef)

  docTokens.forEach(function (token) {
    this.tokenStore.remove(token, docRef)
  }, this)

  if (emitEvent) this.eventEmitter.emit('remove', doc, this)
}

update

lunr.Index.prototype.update()

method

Params

  • doc - The document to update in the index.
  • emitEvent - Whether to emit update events, defaults to true

Updates a document in the index.

When a document contained within the index gets updated, fields changed, added or removed, to make sure it correctly matched against search queries, it should be updated in the index.

This method is just a wrapper around remove and add

An 'update' event is emitted with the document that has been updated and the index. This event can be silenced by passing false as the second argument to update. Only an update event will be fired, the 'add' and 'remove' events of the underlying calls are silenced.

Source

lunr.Index.prototype.update = function (doc, emitEvent) {
  var emitEvent = emitEvent === undefined ? true : emitEvent

  this.remove(doc, false)
  this.add(doc, false)

  if (emitEvent) this.eventEmitter.emit('update', doc, this)
}

idf

lunr.Index.prototype.idf()

method

Params

  • token - The token to calculate the idf of.

Calculates the inverse document frequency for a token within the index.

Source

lunr.Index.prototype.idf = function (term) {
  var cacheKey = "@" + term
  if (Object.prototype.hasOwnProperty.call(this._idfCache, cacheKey)) return this._idfCache[cacheKey]

  var documentFrequency = this.tokenStore.count(term),
      idf = 1

  if (documentFrequency > 0) {
    idf = 1 + Math.log(this.documentStore.length / documentFrequency)
  }

  return this._idfCache[cacheKey] = idf
}

documentVector

lunr.Index.prototype.documentVector()

method

Params

  • documentRef - The ref to find the document with.

Generates a vector containing all the tokens in the document matching the passed documentRef.

The vector contains the tf-idf score for each token contained in the document with the passed documentRef. The vector will contain an element for every token in the indexes corpus, if the document does not contain that token the element will be 0.

Source

lunr.Index.prototype.documentVector = function (documentRef) {
  var documentTokens = this.documentStore.get(documentRef),
      documentTokensLength = documentTokens.length,
      documentVector = new lunr.Vector

  for (var i = 0; i < documentTokensLength; i++) {
    var token = documentTokens.elements[i],
        tf = this.tokenStore.get(token)[documentRef].tf,
        idf = this.idf(token)

    documentVector.insert(this.corpusTokens.indexOf(token), tf * idf)
  };

  return documentVector
}

toJSON

lunr.Index.prototype.toJSON()

method

Returns a representation of the index ready for serialisation.

Source

lunr.Index.prototype.toJSON = function () {
  return {
    version: lunr.version,
    fields: this._fields,
    ref: this._ref,
    tokenizer: this.tokenizerFn.label,
    documentStore: this.documentStore.toJSON(),
    tokenStore: this.tokenStore.toJSON(),
    corpusTokens: this.corpusTokens.toJSON(),
    pipeline: this.pipeline.toJSON()
  }
}

use

lunr.Index.prototype.use()

method

Params

  • plugin - The plugin to apply.

Applies a plugin to the current index.

A plugin is a function that is called with the index as its context. Plugins can be used to customise or extend the behaviour the index in some way. A plugin is just a function, that encapsulated the custom behaviour that should be applied to the index.

The plugin function will be called with the index as its argument, additional arguments can also be passed when calling use. The function will be called with the index as its context.

Example:

var myPlugin = function (idx, arg1, arg2) {
  // `this` is the index to be extended
  // apply any extensions etc here.
}

var idx = lunr(function () {
  this.use(myPlugin, 'arg1', 'arg2')
})

Source

lunr.Index.prototype.use = function (plugin) {
  var args = Array.prototype.slice.call(arguments, 1)
  args.unshift(this)
  plugin.apply(this, args)
}

Store

lunr.Store is a simple key-value store used for storing sets of tokens for documents stored in index.

load

lunr.Store.load()

method

Params

  • serialisedData - The serialised store to load.

Loads a previously serialised store

Source

lunr.Store.load = function (serialisedData) {
  var store = new this

  store.length = serialisedData.length
  store.store = Object.keys(serialisedData.store).reduce(function (memo, key) {
    memo[key] = lunr.SortedSet.load(serialisedData.store[key])
    return memo
  }, {})

  return store
}

set

lunr.Store.prototype.set()

method

Params

  • id - The key used to store the tokens against.
  • tokens - The tokens to store against the key.

Stores the given tokens in the store against the given id.

Source

lunr.Store.prototype.set = function (id, tokens) {
  if (!this.has(id)) this.length++
  this.store[id] = tokens
}

get

lunr.Store.prototype.get()

method

Params

  • id - The key to lookup and retrieve from the store.

Retrieves the tokens from the store for a given key.

Source

lunr.Store.prototype.get = function (id) {
  return this.store[id]
}

has

lunr.Store.prototype.has()

method

Params

  • id - The id to look up in the store.

Checks whether the store contains a key.

Source

lunr.Store.prototype.has = function (id) {
  return id in this.store
}

remove

lunr.Store.prototype.remove()

method

Params

  • id - The id to remove from the store.

Removes the value for a key in the store.

Source

lunr.Store.prototype.remove = function (id) {
  if (!this.has(id)) return

  delete this.store[id]
  this.length--
}

toJSON

lunr.Store.prototype.toJSON()

method

Returns a representation of the store ready for serialisation.

Source

lunr.Store.prototype.toJSON = function () {
  return {
    store: this.store,
    length: this.length
  }
}

stemmer

lunr.stemmer is an english language stemmer, this is a JavaScript implementation of the PorterStemmer taken from http://tartarus.org/~martin

generateStopWordFilter

lunr.generateStopWordFilter builds a stopWordFilter function from the provided list of stop words.

The built in lunr.stopWordFilter is built using this generator and can be used to generate custom stopWordFilters for applications or non English languages.

stopWordFilter

lunr.stopWordFilter is an English language stop word list filter, any words contained in the list will not be passed through the filter.

This is intended to be used in the Pipeline. If the token does not pass the filter then undefined will be returned.

trimmer

lunr.trimmer is a pipeline function for trimming non word characters from the begining and end of tokens before they enter the index.

This implementation may not work correctly for non latin characters and should either be removed or adapted for use with languages with non-latin characters.

TokenStore

lunr.TokenStore is used for efficient storing and lookup of the reverse index of token to document ref.

load

lunr.TokenStore.load()

method

Params

  • serialisedData - The serialised token store to load.

Loads a previously serialised token store

Source

lunr.TokenStore.load = function (serialisedData) {
  var store = new this

  store.root = serialisedData.root
  store.length = serialisedData.length

  return store
}

add

lunr.TokenStore.prototype.add()

method

Params

  • token - The token to store the doc under
  • doc - The doc to store against the token
  • root - An optional node at which to start looking for the

Adds a new token doc pair to the store.

By default this function starts at the root of the current store, however it can start at any node of any token store if required.

Source

lunr.TokenStore.prototype.add = function (token, doc, root) {
  var root = root || this.root,
      key = token.charAt(0),
      rest = token.slice(1)

  if (!(key in root)) root[key] = {docs: {}}

  if (rest.length === 0) {
    root[key].docs[doc.ref] = doc
    this.length += 1
    return
  } else {
    return this.add(rest, doc, root[key])
  }
}

has

lunr.TokenStore.prototype.has()

method

Params

  • token - The token to check for
  • root - An optional node at which to start

Checks whether this key is contained within this lunr.TokenStore.

By default this function starts at the root of the current store, however it can start at any node of any token store if required.

Source

lunr.TokenStore.prototype.has = function (token) {
  if (!token) return false

  var node = this.root

  for (var i = 0; i < token.length; i++) {
    if (!node[token.charAt(i)]) return false

    node = node[token.charAt(i)]
  }

  return true
}

getNode

lunr.TokenStore.prototype.getNode()

method

Params

  • token - The token to get the node for.
  • root - An optional node at which to start.

Retrieve a node from the token store for a given token.

By default this function starts at the root of the current store, however it can start at any node of any token store if required.

Source

lunr.TokenStore.prototype.getNode = function (token) {
  if (!token) return {}

  var node = this.root

  for (var i = 0; i < token.length; i++) {
    if (!node[token.charAt(i)]) return {}

    node = node[token.charAt(i)]
  }

  return node
}

get

lunr.TokenStore.prototype.get()

method

Params

  • token - The token to get the documents for.
  • root - An optional node at which to start.

Retrieve the documents for a node for the given token.

By default this function starts at the root of the current store, however it can start at any node of any token store if required.

Source

lunr.TokenStore.prototype.get = function (token, root) {
  return this.getNode(token, root).docs || {}
}

lunr.TokenStore.prototype.count = function (token, root) {
  return Object.keys(this.get(token, root)).length
}

remove

lunr.TokenStore.prototype.remove()

method

Params

  • token - The token to get the documents for.
  • ref - The ref of the document to remove from this token.
  • root - An optional node at which to start.

Remove the document identified by ref from the token in the store.

By default this function starts at the root of the current store, however it can start at any node of any token store if required.

Source

lunr.TokenStore.prototype.remove = function (token, ref) {
  if (!token) return
  var node = this.root

  for (var i = 0; i < token.length; i++) {
    if (!(token.charAt(i) in node)) return
    node = node[token.charAt(i)]
  }

  delete node.docs[ref]
}

expand

lunr.TokenStore.prototype.expand()

method

Params

  • token - The token to expand.

Find all the possible suffixes of the passed token using tokens currently in the store.

Source

lunr.TokenStore.prototype.expand = function (token, memo) {
  var root = this.getNode(token),
      docs = root.docs || {},
      memo = memo || []

  if (Object.keys(docs).length) memo.push(token)

  Object.keys(root)
    .forEach(function (key) {
      if (key === 'docs') return

      memo.concat(this.expand(token + key, memo))
    }, this)

  return memo
}

toJSON

lunr.TokenStore.prototype.toJSON()

method

Returns a representation of the token store ready for serialisation.

Source

lunr.TokenStore.prototype.toJSON = function () {
  return {
    root: this.root,
    length: this.length
  }
}