• 设为首页
  • 点击收藏
  • 手机版
    手机扫一扫访问
    迪恩网络手机版
  • 关注官方公众号
    微信扫一扫关注
    公众号

Scala MurmurHash3类代码示例

原作者: [db:作者] 来自: [db:来源] 收藏 邀请

本文整理汇总了Scala中scala.util.hashing.MurmurHash3的典型用法代码示例。如果您正苦于以下问题:Scala MurmurHash3类的具体用法?Scala MurmurHash3怎么用?Scala MurmurHash3使用的例子?那么恭喜您, 这里精选的类代码示例或许可以为您提供帮助。



在下文中一共展示了MurmurHash3类的6个代码示例,这些例子默认根据受欢迎程度排序。您可以为喜欢或者感觉有用的代码点赞,您的评价将有助于我们的系统推荐出更棒的Scala代码示例。

示例1: ironMqClient

//设置package包名称以及导入依赖的类
package akka.stream.alpakka.ironmq

import java.util.UUID

import com.typesafe.config.{Config, ConfigFactory}
import org.scalatest.concurrent.ScalaFutures
import org.scalatest.{BeforeAndAfterEach, Notifying, Suite}

import scala.concurrent.ExecutionContext
import scala.util.hashing.MurmurHash3

trait IronMqFixture extends AkkaStreamFixture with BeforeAndAfterEach with ScalaFutures { _: Suite with Notifying =>

  private implicit val ec = ExecutionContext.global
  private var mutableIronMqClient = Option.empty[IronMqClient]

  def ironMqClient: IronMqClient =
    mutableIronMqClient.getOrElse(throw new IllegalStateException("The IronMqClient is not initialized"))

  override protected def initConfig(): Config =
    ConfigFactory.parseString(s"""akka.stream.alpakka.ironmq {
        |  credentials {
        |    project-id = "${MurmurHash3.stringHash(System.currentTimeMillis().toString)}"
        |  }
        |}
      """.stripMargin).withFallback(super.initConfig())

  override protected def beforeEach(): Unit = {
    super.beforeEach()
    mutableIronMqClient = Option(IronMqClient(IronMqSettings(config.getConfig("akka.stream.alpakka.ironmq"))))
  }

  override protected def afterEach(): Unit = {
    mutableIronMqClient = Option.empty
    super.afterEach()
  }

  def givenQueue(name: Queue.Name): Queue = {
    val created = ironMqClient.createQueue(name).futureValue
    note(s"Queue created: ${created.name.value}", Some(created))
    created
  }

  def givenQueue(): Queue =
    givenQueue(Queue.Name(s"test-${UUID.randomUUID()}"))
} 
开发者ID:akka,项目名称:alpakka,代码行数:47,代码来源:IronMqFixture.scala


示例2: Range

//设置package包名称以及导入依赖的类
package org.cddb.store

import akka.actor.{Actor, ActorRef}
import akka.event.Logging

import scala.util.hashing.MurmurHash3

case class Range(start: Long, end: Long)

class Master(distributor: Distributor, hashFunc: (String => Long)) extends Actor {
  val log = Logging(context.system, this)

  override def receive = {
    case Init() =>
    case Insert(obj: StoreObject, caller: ActorRef) =>
      log.debug(s"Received Insert message: $obj")
      distributor.distribute(hashFunc(obj.key)) ! Insert(obj, caller)
    case Retrieve(key: String, caller: ActorRef) =>
      log.debug(s"Received Retrieve message: $key, caller: $caller")
      distributor.distribute(hashFunc(key)) ! Retrieve(key, caller)
    case Delete(key: String, caller: ActorRef) =>
      log.debug(s"Received Delete message: $key, caller: $caller")
      distributor.distribute(hashFunc(key)) ! Delete(key, caller)
    case _ => log.info("unknown message")
  }

}

class Distributor(f: (String => ActorRef)) {

  private val ranges = Array.fill[Range](1)(Range(0, Long.MaxValue))
  private val nodes = Array.fill[ActorRef](1)(f("test"))

  def distribute(hash: Long): ActorRef = nodes(0)

}

object Master {

  def hashFunc(str: String): Long = {
    val a = str.toCharArray.map(_.toByte)
    val hash1 = MurmurHash3.arrayHash(a)
    val hash2 = MurmurHash3.arrayHash(a.reverse)
    hash1 * hash2
  }

  def main(args: Array[String]): Unit = {
  }

} 
开发者ID:tierex,项目名称:cddb,代码行数:51,代码来源:Master.scala


示例3: BloomFilter

//设置package包名称以及导入依赖的类
package org.janzhou.hashing

import scala.util.hashing.MurmurHash3
import scala.collection.mutable.BitSet
import scala.reflect.ClassTag

class BloomFilter[T:ClassTag](
  val numBuckets: Int,
  val numHashFunctions: Int,
  val bits: BitSet
) {
  def this(numBuckets: Int, numHashFunctions: Int) = this(numBuckets, numHashFunctions, new BitSet(numBuckets))
  def this(numBuckets: Int) = this(numBuckets, 3)

  def hashValues(key: T) = {
    val hash1 = key.##
    val hash2 = math.abs(MurmurHash3.mixLast(0, hash1))

    for {
      i <- 0 to numHashFunctions
    } yield {
      val h = hash1 + i * hash2
      val nextHash = if (h < 0) ~h else h
      nextHash % numBuckets
    }
  }

  def containsHashes(hashes:Iterable[Int]):Boolean = {
    hashes.forall(i => bits.contains(i))
  }

  def contains(o: T): Boolean = {
    containsHashes(hashValues(o))
  }

  
  def optimallySized[T:ClassTag](expectedNumItems: Double, falsePositiveRate: Double): BloomFilter[T] = {
    val (buckets, funs) = optimalSize(expectedNumItems, falsePositiveRate)
    new BloomFilter[T](buckets, funs)
  }
} 
开发者ID:janzhou,项目名称:BloomFilterTree,代码行数:42,代码来源:BloomFilter.scala


示例4: afterEach

//设置package包名称以及导入依赖的类
package com.github.filosganga.ironmqrx

import akka.Done
import org.scalatest.concurrent.{Futures, ScalaFutures}
import org.scalatest.{Notifying, BeforeAndAfterAll, BeforeAndAfterEach, Suite}

import scala.concurrent.{ExecutionContext, Future}
import scala.util.hashing.MurmurHash3

trait IronMqFixture extends AkkaFixture with BeforeAndAfterEach with BeforeAndAfterAll with ScalaFutures {
  _: Suite with Notifying =>

  private implicit val ec = ExecutionContext.global
  private var queues: Set[Queue.Name] = Set.empty

  lazy val ironMqClient: IronMqClient = IronMqClient(actorSystem)

  override protected def afterEach(): Unit = {
    Future.sequence(queues.map(ironMqClient.deleteQueue)).futureValue
    queues = Set.empty
    super.afterEach()
  }

  override protected def afterAll(): Unit = {
    ironMqClient.close()
    super.afterAll()
  }

  def givenQueue(name: Queue.Name): Queue = {
    val created = ironMqClient.createQueue(name).futureValue
    note(s"Queue created: ${created.name.value}", Some(created))
    queues = queues + created.name
    created
  }

  def givenQueue(): Queue = {
    givenQueue(Queue.Name(s"test-${MurmurHash3.stringHash(System.currentTimeMillis().toString)}"))
  }
} 
开发者ID:filosganga,项目名称:ironmq.rx,代码行数:40,代码来源:IronMqFixture.scala


示例5: Bytes

//设置package包名称以及导入依赖的类
package com.avsystem.scex.util

import java.io.UnsupportedEncodingException
import java.nio.charset.StandardCharsets

import com.avsystem.commons.jiop.JavaInterop._
import com.avsystem.scex.presentation.annotation.Documentation
import org.apache.commons.codec.binary.{Base64, Hex}

import scala.collection.mutable
import scala.util.hashing.MurmurHash3

final class Bytes(val bytes: Array[Byte]) extends Comparable[Bytes] {
  override def hashCode(): Int = MurmurHash3.bytesHash(bytes)
  override def equals(other: Any): Boolean = other match {
    case b: Bytes => java.util.Arrays.equals(bytes, b.bytes)
    case _ => false
  }
  override def toString: String = s"Bytes($escaped)"
  override def compareTo(o: Bytes): Int = {
    def loop(i: Int): Int =
      if (i == bytes.length && i == o.bytes.length) 0
      else if (i == bytes.length) -1
      else if (i == o.bytes.length) 1
      else {
        val b1 = bytes(i)
        val b2 = o.bytes(i)
        if (b1 == b2) loop(i + 1) else b1 - b2
      }
    loop(0)
  }

  @Documentation("Encodes this sequence of bytes as string with non-ASCII bytes and backslash escaped, e.g. 'hsg\\x7c\\x0dfoo\\\\bar'")
  def escaped: String = EscapedBytes.render(bytes)

  @Documentation("Encodes this sequence of bytes as hexadecimal string")
  def hex: String = Hex.encodeHexString(bytes)

  @Documentation("Encodes this sequence of bytes as BASE64 string")
  def base64: String = Base64.encodeBase64String(bytes)

  @Documentation("Decodes this sequence of bytes as UTF-8 string")
  def decodeUTF8: String = new String(bytes, StandardCharsets.UTF_8)

  @Documentation("Decodes this sequence of bytes as string using given charset")
  def decode(charset: String): String =
    try new String(bytes, charset) catch {
      case e: UnsupportedEncodingException => throw new IllegalArgumentException(e)
    }

  def asList: JList[Byte] = new mutable.WrappedArray.ofByte(bytes).asJava
} 
开发者ID:AVSystem,项目名称:scex,代码行数:53,代码来源:Bytes.scala


示例6: aultHashCode

//设置package包名称以及导入依赖的类
package teleporter.integration.utils

import scala.util.hashing.MurmurHash3


trait Hashing {
  val defaultHashCode: Int = -1
  val defaultHashByteArray: Array[Byte] = Bytes.toBytes(defaultHashCode)

  def hashValue(value: Any): Int = {
    val bytes = Option(value).map(Bytes.to).getOrElse(defaultHashByteArray)
    MurmurHash3.bytesHash(bytes)
  }

  def hash(seq: Traversable[Any]): Seq[Byte] = {
    seq.map(hashValue).flatMap(i ? Bytes.toBytes(i)).toSeq
  }

  def hash(m: Map[String, Any]): Seq[Byte] = {
    hash(m.values)
  }

  def hash(keys: Seq[String], m: Map[String, Any]): Seq[Byte] = {
    hash(keys.map(m(_)))
  }
}

object Hashing extends Hashing

trait ColumnFilter extends Hashing {
  def filterChanges(m: Map[String, Any], hashCodes: Array[Byte]): Map[String, Any] = {
    if (m.size * 4 != hashCodes.length) return m
    var i = -1
    m.filter { case (_, v) ? i += 1; hashValue(v) != Bytes.toInt(hashCodes.slice(i * 4, i * 4 + 4)) }
  }

  def filterChanges(keys: Seq[String], m: Map[String, Any], hashCodes: Array[Byte]): Map[String, Any] = {
    if (keys.size == hashCodes.length) return m
    var i = -1
    val filterKeys = keys.filter {
      key ? i += 1; m.getOrElse(key, defaultHashCode) != Bytes.toInt(hashCodes.slice(i * 4, i * 4 + 4))
    }.toSet
    m.filterKeys(filterKeys.contains)
  }
}

object ColumnFilter extends ColumnFilter 
开发者ID:huanwuji,项目名称:teleporter,代码行数:48,代码来源:ColumnFilter.scala



注:本文中的scala.util.hashing.MurmurHash3类示例整理自Github/MSDocs等源码及文档管理平台,相关代码片段筛选自各路编程大神贡献的开源项目,源码版权归原作者所有,传播和使用请参考对应项目的License;未经允许,请勿转载。


鲜花

握手

雷人

路过

鸡蛋
该文章已有0人参与评论

请发表评论

全部评论

专题导读
上一篇:
Scala RandomAccessFile类代码示例发布时间:2022-05-23
下一篇:
Scala DenseVector类代码示例发布时间:2022-05-23
热门推荐
热门话题
阅读排行榜

扫描微信二维码

查看手机版网站

随时了解更新最新资讯

139-2527-9053

在线客服(服务时间 9:00~18:00)

在线QQ客服
地址:深圳市南山区西丽大学城创智工业园
电邮:jeky_zhao#qq.com
移动电话:139-2527-9053

Powered by 互联科技 X3.4© 2001-2213 极客世界.|Sitemap