91超碰碰碰碰久久久久久综合_超碰av人澡人澡人澡人澡人掠_国产黄大片在线观看画质优化_txt小说免费全本

溫馨提示×

溫馨提示×

您好,登錄后才能下訂單哦!

密碼登錄×
登錄注冊×
其他方式登錄
點擊 登錄注冊 即表示同意《億速云用戶服務條款》

Scala 操作Redis使用連接池工具類RedisUtil

發布時間:2020-09-15 15:29:00 來源:腳本之家 閱讀:645 作者:Gavin-Feng 欄目:編程語言

本文介紹了Scala 操作Redis,分享給大家,具體如下:

package com.zjw.util

import java.util

import org.apache.commons.pool2.impl.GenericObjectPoolConfig
import org.apache.logging.log4j.scala.Logging
import redis.clients.jedis.{Jedis, JedisPool, Response}
import redis.clients.util.Pool

object RedisUtil extends Logging {
 private[this] var jedisPool: Pool[Jedis] = _

 def main(args: Array[String]): Unit = {
  val password = "h-{<Fc!yJL87_Zkc8S"
  val host = "192.168.100.101"
  val port = 6379
  val timeout = 1000
  RedisUtil.init(host, port, timeout, password, 0)
  //RedisUtil.set("Time".getBytes(), "2018-09-03 09:00:00".getBytes())
  //val result = RedisUtil.get("Time".getBytes())
  //println(new String(result))
  //val map = Map("name"-> "zhangsan","age"-> "21", "gender"-> "male", "id"-> "519099386")
  //RedisUtil.setCols("hash",map)

  // val result = RedisUtil.getCols("hash", Array("name", "age", "xx")).map(x => (x._1, new String(x._2)))
  // logger.info(result)
  val result = RedisUtil.bulkGetCols(Array("hash", "ss"))
  logger.info(s"result: ${result}")
 }

 def init(host: String, port: Int, timeout: Int, password: String, database: Int = 0): Unit = {
  jedisPool = new JedisPool(new GenericObjectPoolConfig, host, port, timeout, password, database)
 }

 def get(key: Array[Byte]): Array[Byte] = {
  val jedis = jedisPool.getResource
  val result: Array[Byte] = jedis.get(key)
  jedis.close()
  result
 }

 def set(key: Array[Byte], value: Array[Byte]): Boolean = {
  try {
   val jedis = jedisPool.getResource
   jedis.set(key, value)
   jedis.close()
   true
  } catch {
   case e: Exception => {
    logger.error(s"寫入數據到Redis出錯: ${e}")
    false
   }
  }
 }


 def getCols(key: String,
       cols: Array[String] = Array.empty
       ): Map[String, Array[Byte]] = {
  import scala.collection.JavaConverters._
  val jedis = jedisPool.getResource
  var map = Map.empty[String, Array[Byte]]
  if (cols.length > 0) {
   val pipe = jedis.pipelined()
   val response = pipe.hmget(key.getBytes(), cols.map(_.getBytes()): _*)
   pipe.sync()
   map = cols.zip(response.get.asScala).toMap.filter(x => x._2 != null)
   pipe.close()
  } else {
   logger.info(s"key: ${key}")
   val tmpMap: util.Map[Array[Byte], Array[Byte]] = jedis.hgetAll(key.getBytes())
   map = tmpMap.asScala.toMap.map(x => (new String(x._1), x._2))
  }
  jedis.close
  map
 }

 def getCols2(
        key: String,
        cols: Array[String] = Array.empty
       ): Map[String, Array[Byte]] = {
  val jedis = jedisPool.getResource
  var map = Map.empty[String, Array[Byte]]
  if (cols.length > 0) {
   for (col <- cols) {
    val value: Array[Byte] = jedis.hget(key.getBytes(), col.getBytes())
    if (null != value) {
     map = map + (col -> value)
    }
   }
  } else {
   logger.info(s"rowkey: ${key}")
   val tmpMap: util.Map[Array[Byte], Array[Byte]] = jedis.hgetAll(key.getBytes())
   import scala.collection.JavaConverters._
   map = tmpMap.asScala.toMap.map(x => (new String(x._1), x._2))
  }
  jedis.close
  map
 }

 def bulkGetCols(keys: Array[String],
         cols: Array[String] = Array.empty
         ): Map[String, Map[String, Array[Byte]]] = {
  import scala.collection.JavaConverters._
  var result: Map[String, Map[String, Array[Byte]]] = Map.empty
  val jedis = jedisPool.getResource
  val pipe = jedis.pipelined
  if (cols.length > 0) {
   val data = keys.map(x => {
    pipe.hmget(x.getBytes(), cols.map(_.getBytes()): _*)
   })

   pipe.sync
   pipe.close
   jedis.close

   result = keys.zip(data.map(_.get().asScala.toArray).map(cols.zip(_).toMap.filter(null != _._2)))
    .toMap.filter(_._2.nonEmpty)
  } else {
   val data: Array[Response[util.Map[Array[Byte], Array[Byte]]]] = keys.map(x => {
    pipe.hgetAll(x.getBytes())
   })
   pipe.sync
   pipe.close
   jedis.close

   result = keys.zip(data.map(_.get().asScala.map(x => (new String(x._1), x._2)).toMap))
    .toMap.filter(_._2.nonEmpty)
  }
  result
 }

 def bulkGetCols2(rowkeys: Array[String],
         cols: Array[String] = Array.empty
         ): Map[String, Map[String, Array[Byte]]] = {
  val jedis = jedisPool.getResource
  var map = Map.empty[String, Map[String, Array[Byte]]]
  import scala.collection.JavaConverters._
  for (rowkey <- rowkeys) {
   var cellMap = Map.empty[String, Array[Byte]]
   if (cols.length > 0) {
    for (col <- cols) {
     val value = jedis.hget(rowkey.getBytes(), col.getBytes())
     if (null != value) {
      cellMap = cellMap + (col -> value)
     }
    }
   } else {
    logger.info(s"rowkey: ${rowkey}")
    val tmpMap = jedis.hgetAll(rowkey.getBytes())
    cellMap = tmpMap.asScala.toMap.map(x => (new String(x._1), x._2))
   }
   if (cellMap.nonEmpty) {
    map = map + (rowkey -> cellMap)
   }
  }
  jedis.close
  map
 }

 def setCols(
        key: String,
        fieldValues: Map[String, String]
       ): Unit = {
  import scala.collection.JavaConverters._
  val data = fieldValues.map(element => {
   (element._1.getBytes(), element._2.getBytes())
  }).asJava
  val jedis = jedisPool.getResource
  jedis.hmset(key.getBytes(), data)
  jedis.close()
 }

}

以上就是本文的全部內容,希望對大家的學習有所幫助,也希望大家多多支持億速云。

向AI問一下細節

免責聲明:本站發布的內容(圖片、視頻和文字)以原創、轉載和分享為主,文章觀點不代表本網站立場,如果涉及侵權請聯系站長郵箱:is@yisu.com進行舉報,并提供相關證據,一經查實,將立刻刪除涉嫌侵權內容。

AI

赣州市| 白河县| 澳门| 德州市| 思茅市| 什邡市| 古蔺县| 辽阳市| 汉沽区| 安岳县| 宁都县| 银川市| 江陵县| 西乡县| 广灵县| 灵山县| 涞源县| 开封市| 华坪县| 哈巴河县| 浦城县| 富顺县| 昌都县| 壶关县| 河曲县| 海伦市| 呼伦贝尔市| 安龙县| 拉孜县| 华阴市| 江川县| 延长县| 莆田市| 和龙市| 建湖县| 富蕴县| 白城市| 东乌| 毕节市| 洪洞县| 遂宁市|