mirror of
https://github.com/TheAnachronism/docspell.git
synced 2025-04-05 10:59:33 +00:00
commit
ce497b05ff
@ -65,7 +65,7 @@ object FileCopyTask {
|
|||||||
if (result.success)
|
if (result.success)
|
||||||
s"Successfully copied $allGood files to ${result.counter.size} stores."
|
s"Successfully copied $allGood files to ${result.counter.size} stores."
|
||||||
else
|
else
|
||||||
s"Copying files failed for ${failed} files! ${allGood} were copied successfully."
|
s"Copying files failed for ${failed} files! $allGood were copied successfully."
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
@ -122,8 +122,8 @@ object FileCopyTask {
|
|||||||
case None =>
|
case None =>
|
||||||
CopyResult.noSourceImpl.pure[F]
|
CopyResult.noSourceImpl.pure[F]
|
||||||
|
|
||||||
case Some((src, srcMeta)) =>
|
case Some(src) =>
|
||||||
to.traverse(FileRepository.getDelegate).map(_.map(_._1)) match {
|
to.traverse(FileRepository.getDelegate) match {
|
||||||
case None =>
|
case None =>
|
||||||
CopyResult.noTargetImpl.pure[F]
|
CopyResult.noTargetImpl.pure[F]
|
||||||
|
|
||||||
@ -135,7 +135,7 @@ object FileCopyTask {
|
|||||||
}
|
}
|
||||||
|
|
||||||
def copyTo(to: BinaryStore[F]) =
|
def copyTo(to: BinaryStore[F]) =
|
||||||
CopyTool.copyAll[F](log, src, srcMeta, to, 50, maxConcurrent)
|
CopyTool.copyAll[F](log, src, to, 50, maxConcurrent)
|
||||||
|
|
||||||
logger.info(s"Start copying ${from.config} -> ${to.map(_.config)}") *>
|
logger.info(s"Start copying ${from.config} -> ${to.map(_.config)}") *>
|
||||||
targets.traverse(copyTo).map(CopyResult.success)
|
targets.traverse(copyTo).map(CopyResult.success)
|
||||||
|
@ -13,8 +13,8 @@ import scribe.output.format.OutputFormat
|
|||||||
import scribe.writer._
|
import scribe.writer._
|
||||||
|
|
||||||
final case class JsonWriter(writer: Writer, compact: Boolean = true) extends Writer {
|
final case class JsonWriter(writer: Writer, compact: Boolean = true) extends Writer {
|
||||||
override def write[M](
|
override def write(
|
||||||
record: LogRecord[M],
|
record: LogRecord,
|
||||||
output: LogOutput,
|
output: LogOutput,
|
||||||
outputFormat: OutputFormat
|
outputFormat: OutputFormat
|
||||||
): Unit = {
|
): Unit = {
|
||||||
|
@ -14,8 +14,8 @@ import scribe.writer._
|
|||||||
|
|
||||||
// https://brandur.org/logfmt
|
// https://brandur.org/logfmt
|
||||||
final case class LogfmtWriter(writer: Writer) extends Writer {
|
final case class LogfmtWriter(writer: Writer) extends Writer {
|
||||||
override def write[M](
|
override def write(
|
||||||
record: LogRecord[M],
|
record: LogRecord,
|
||||||
output: LogOutput,
|
output: LogOutput,
|
||||||
outputFormat: OutputFormat
|
outputFormat: OutputFormat
|
||||||
): Unit = {
|
): Unit = {
|
||||||
|
@ -38,18 +38,23 @@ private[impl] case class Record(
|
|||||||
|
|
||||||
private[impl] object Record {
|
private[impl] object Record {
|
||||||
|
|
||||||
def fromLogRecord[M](record: LogRecord[M]): Record = {
|
def fromLogRecord(record: LogRecord): Record = {
|
||||||
val l = record.timeStamp
|
val l = record.timeStamp
|
||||||
val traces = record.additionalMessages.collect {
|
val traces = record.messages.collect {
|
||||||
case message: Message[_] if message.value.isInstanceOf[Throwable] =>
|
case message: Message[_] if message.value.isInstanceOf[Throwable] =>
|
||||||
throwable2Trace(message.value.asInstanceOf[Throwable])
|
throwable2Trace(message.value.asInstanceOf[Throwable])
|
||||||
}
|
}
|
||||||
val additionalMessages = record.additionalMessages.map(_.logOutput.plainText)
|
val (firstMessage, additionalMessages) = record.messages match {
|
||||||
|
case h :: rest =>
|
||||||
|
(h.logOutput.plainText, rest.map(_.logOutput.plainText))
|
||||||
|
case Nil =>
|
||||||
|
("", Nil)
|
||||||
|
}
|
||||||
|
|
||||||
Record(
|
Record(
|
||||||
level = record.level.name,
|
level = record.level.name,
|
||||||
levelValue = record.levelValue,
|
levelValue = record.levelValue,
|
||||||
message = record.logOutput.plainText,
|
message = firstMessage,
|
||||||
additionalMessages = additionalMessages,
|
additionalMessages = additionalMessages,
|
||||||
fileName = record.fileName,
|
fileName = record.fileName,
|
||||||
className = record.className,
|
className = record.className,
|
||||||
|
@ -12,7 +12,7 @@ import cats.effect.Sync
|
|||||||
import docspell.logging.{Level, LogEvent, Logger}
|
import docspell.logging.{Level, LogEvent, Logger}
|
||||||
|
|
||||||
import scribe.LoggerSupport
|
import scribe.LoggerSupport
|
||||||
import scribe.message.{LoggableMessage, Message}
|
import scribe.message.LoggableMessage
|
||||||
|
|
||||||
private[logging] object ScribeWrapper {
|
private[logging] object ScribeWrapper {
|
||||||
final class ImplUnsafe(log: scribe.Logger) extends Logger[Id] {
|
final class ImplUnsafe(log: scribe.Logger) extends Logger[Id] {
|
||||||
@ -41,10 +41,10 @@ private[logging] object ScribeWrapper {
|
|||||||
private[this] def convert(ev: LogEvent) = {
|
private[this] def convert(ev: LogEvent) = {
|
||||||
val level = convertLevel(ev.level)
|
val level = convertLevel(ev.level)
|
||||||
val additional: List[LoggableMessage] = ev.additional.map {
|
val additional: List[LoggableMessage] = ev.additional.map {
|
||||||
case Right(ex) => Message.static(ex)
|
case Right(ex) => LoggableMessage.throwable2Message(ex)
|
||||||
case Left(msg) => Message.static(msg)
|
case Left(msg) => LoggableMessage.string2Message(msg)
|
||||||
}.toList
|
}.toList
|
||||||
LoggerSupport(level, ev.msg(), additional, ev.pkg, ev.fileName, ev.name, ev.line)
|
LoggerSupport(level, ev.msg() :: additional, ev.pkg, ev.fileName, ev.name, ev.line)
|
||||||
.copy(data = ev.data.toDeferred)
|
.copy(data = ev.data.toDeferred)
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -60,7 +60,7 @@ object Store {
|
|||||||
ds.setDriverClassName(jdbc.dbms.driverClass)
|
ds.setDriverClassName(jdbc.dbms.driverClass)
|
||||||
}
|
}
|
||||||
xa = HikariTransactor(ds, connectEC)
|
xa = HikariTransactor(ds, connectEC)
|
||||||
fr = FileRepository.apply(xa, ds, fileRepoConfig, true)
|
fr = FileRepository(xa, ds, fileRepoConfig, true)
|
||||||
st = new StoreImpl[F](fr, jdbc, schemaCfg, ds, xa)
|
st = new StoreImpl[F](fr, jdbc, schemaCfg, ds, xa)
|
||||||
_ <- Resource.eval(st.migrate)
|
_ <- Resource.eval(st.migrate)
|
||||||
} yield st
|
} yield st
|
||||||
|
@ -18,71 +18,52 @@ import binny._
|
|||||||
import doobie._
|
import doobie._
|
||||||
import doobie.implicits._
|
import doobie.implicits._
|
||||||
|
|
||||||
private[file] trait AttributeStore[F[_]] extends BinaryAttributeStore[F] {
|
trait AttributeStore[F[_]] {
|
||||||
def findMeta(id: BinaryId): OptionT[F, RFileMeta]
|
def saveAttr(key: FileKey, attrs: BinaryAttributes): F[Unit]
|
||||||
|
|
||||||
|
def deleteAttr(key: FileKey): F[Boolean]
|
||||||
|
|
||||||
|
def findMeta(key: FileKey): OptionT[F, RFileMeta]
|
||||||
}
|
}
|
||||||
|
|
||||||
private[file] object AttributeStore {
|
private[file] object AttributeStore {
|
||||||
def empty[F[_]: Applicative]: AttributeStore[F] =
|
def empty[F[_]: Applicative]: AttributeStore[F] =
|
||||||
new AttributeStore[F] {
|
new AttributeStore[F] {
|
||||||
val delegate = BinaryAttributeStore.empty[F]
|
override def saveAttr(key: FileKey, attrs: BinaryAttributes) = ().pure[F]
|
||||||
|
|
||||||
def findMeta(id: BinaryId) =
|
override def deleteAttr(key: FileKey) = false.pure[F]
|
||||||
OptionT.none
|
|
||||||
|
|
||||||
def saveAttr(id: BinaryId, attrs: F[BinaryAttributes]) =
|
override def findMeta(key: FileKey) = OptionT.none[F, RFileMeta]
|
||||||
delegate.saveAttr(id, attrs)
|
|
||||||
|
|
||||||
def deleteAttr(id: BinaryId) =
|
|
||||||
delegate.deleteAttr(id)
|
|
||||||
|
|
||||||
def findAttr(id: BinaryId) =
|
|
||||||
delegate.findAttr(id)
|
|
||||||
}
|
}
|
||||||
|
|
||||||
def apply[F[_]: Sync](xa: Transactor[F]): AttributeStore[F] =
|
def apply[F[_]: Sync](xa: Transactor[F]): AttributeStore[F] =
|
||||||
new Impl[F](xa)
|
new Impl[F](xa)
|
||||||
|
|
||||||
final private class Impl[F[_]: Sync](xa: Transactor[F]) extends AttributeStore[F] {
|
final private class Impl[F[_]: Sync](xa: Transactor[F]) extends AttributeStore[F] {
|
||||||
def saveAttr(id: BinaryId, attrs: F[BinaryAttributes]): F[Unit] =
|
def saveAttr(key: FileKey, attrs: BinaryAttributes): F[Unit] =
|
||||||
for {
|
for {
|
||||||
now <- Timestamp.current[F]
|
now <- Timestamp.current[F]
|
||||||
a <- attrs
|
|
||||||
fileKey <- makeFileKey(id)
|
|
||||||
fm = RFileMeta(
|
fm = RFileMeta(
|
||||||
fileKey,
|
key,
|
||||||
now,
|
now,
|
||||||
MimeType.parse(a.contentType.contentType).getOrElse(MimeType.octetStream),
|
MimeType.parse(attrs.contentType.contentType).getOrElse(MimeType.octetStream),
|
||||||
ByteSize(a.length),
|
ByteSize(attrs.length),
|
||||||
a.sha256
|
attrs.sha256
|
||||||
)
|
)
|
||||||
_ <- RFileMeta.insert(fm).transact(xa)
|
_ <- RFileMeta.insert(fm).transact(xa)
|
||||||
} yield ()
|
} yield ()
|
||||||
|
|
||||||
def deleteAttr(id: BinaryId): F[Boolean] =
|
def deleteAttr(key: FileKey): F[Boolean] =
|
||||||
makeFileKey(id).flatMap(fileKey =>
|
RFileMeta.delete(key).transact(xa).map(_ > 0)
|
||||||
RFileMeta.delete(fileKey).transact(xa).map(_ > 0)
|
|
||||||
)
|
|
||||||
|
|
||||||
def findAttr(id: BinaryId): OptionT[F, BinaryAttributes] =
|
def findMeta(key: FileKey): OptionT[F, RFileMeta] =
|
||||||
findMeta(id).map(fm =>
|
OptionT(RFileMeta.findById(key).transact(xa))
|
||||||
BinaryAttributes(
|
|
||||||
fm.checksum,
|
|
||||||
SimpleContentType(fm.mimetype.asString),
|
|
||||||
fm.length.bytes
|
|
||||||
)
|
|
||||||
)
|
|
||||||
|
|
||||||
def findMeta(id: BinaryId): OptionT[F, RFileMeta] =
|
// private def makeFileKey(binaryId: BinaryId): F[FileKey] =
|
||||||
OptionT(
|
// Sync[F]
|
||||||
makeFileKey(id).flatMap(fileKey => RFileMeta.findById(fileKey).transact(xa))
|
// .pure(
|
||||||
)
|
// BinnyUtils.binaryIdToFileKey(binaryId).left.map(new IllegalStateException(_))
|
||||||
|
// )
|
||||||
private def makeFileKey(binaryId: BinaryId): F[FileKey] =
|
// .rethrow
|
||||||
Sync[F]
|
|
||||||
.pure(
|
|
||||||
BinnyUtils.binaryIdToFileKey(binaryId).left.map(new IllegalStateException(_))
|
|
||||||
)
|
|
||||||
.rethrow
|
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -16,7 +16,7 @@ import docspell.files.TikaMimetype
|
|||||||
import docspell.logging.Logger
|
import docspell.logging.Logger
|
||||||
|
|
||||||
import binny._
|
import binny._
|
||||||
import binny.fs.{FsBinaryStore, FsStoreConfig, PathMapping}
|
import binny.fs._
|
||||||
import binny.jdbc.{GenericJdbcStore, JdbcStoreConfig}
|
import binny.jdbc.{GenericJdbcStore, JdbcStoreConfig}
|
||||||
import binny.minio.{MinioBinaryStore, MinioConfig, S3KeyMapping}
|
import binny.minio.{MinioBinaryStore, MinioConfig, S3KeyMapping}
|
||||||
import scodec.bits.ByteVector
|
import scodec.bits.ByteVector
|
||||||
@ -95,7 +95,6 @@ object BinnyUtils {
|
|||||||
|
|
||||||
def binaryStore[F[_]: Async](
|
def binaryStore[F[_]: Async](
|
||||||
cfg: FileRepositoryConfig,
|
cfg: FileRepositoryConfig,
|
||||||
attrStore: AttributeStore[F],
|
|
||||||
ds: DataSource,
|
ds: DataSource,
|
||||||
logger: Logger[F]
|
logger: Logger[F]
|
||||||
): BinaryStore[F] =
|
): BinaryStore[F] =
|
||||||
@ -103,7 +102,7 @@ object BinnyUtils {
|
|||||||
case FileRepositoryConfig.Database(chunkSize) =>
|
case FileRepositoryConfig.Database(chunkSize) =>
|
||||||
val jdbcConfig =
|
val jdbcConfig =
|
||||||
JdbcStoreConfig("filechunk", chunkSize, BinnyUtils.TikaContentTypeDetect)
|
JdbcStoreConfig("filechunk", chunkSize, BinnyUtils.TikaContentTypeDetect)
|
||||||
GenericJdbcStore[F](ds, LoggerAdapter(logger), jdbcConfig, attrStore)
|
GenericJdbcStore[F](ds, LoggerAdapter(logger), jdbcConfig)
|
||||||
|
|
||||||
case FileRepositoryConfig.S3(endpoint, accessKey, secretKey, bucket, chunkSize) =>
|
case FileRepositoryConfig.S3(endpoint, accessKey, secretKey, bucket, chunkSize) =>
|
||||||
val keyMapping = S3KeyMapping.constant(bucket)
|
val keyMapping = S3KeyMapping.constant(bucket)
|
||||||
@ -111,16 +110,16 @@ object BinnyUtils {
|
|||||||
.default(endpoint, accessKey, secretKey, keyMapping)
|
.default(endpoint, accessKey, secretKey, keyMapping)
|
||||||
.copy(chunkSize = chunkSize, detect = BinnyUtils.TikaContentTypeDetect)
|
.copy(chunkSize = chunkSize, detect = BinnyUtils.TikaContentTypeDetect)
|
||||||
|
|
||||||
MinioBinaryStore[F](minioCfg, attrStore, LoggerAdapter(logger))
|
MinioBinaryStore[F](minioCfg, LoggerAdapter(logger))
|
||||||
|
|
||||||
case FileRepositoryConfig.Directory(path, chunkSize) =>
|
case FileRepositoryConfig.Directory(path, chunkSize) =>
|
||||||
val fsConfig = FsStoreConfig(
|
val fsConfig = FsStoreConfig(
|
||||||
path,
|
path,
|
||||||
BinnyUtils.TikaContentTypeDetect,
|
BinnyUtils.TikaContentTypeDetect,
|
||||||
FsStoreConfig.OverwriteMode.Fail,
|
OverwriteMode.Fail,
|
||||||
BinnyUtils.pathMapping,
|
BinnyUtils.pathMapping,
|
||||||
chunkSize
|
chunkSize
|
||||||
)
|
)
|
||||||
FsBinaryStore[F](fsConfig, LoggerAdapter(logger), attrStore)
|
FsBinaryStore[F](fsConfig, LoggerAdapter(logger))
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -13,7 +13,7 @@ import fs2._
|
|||||||
|
|
||||||
import docspell.common._
|
import docspell.common._
|
||||||
|
|
||||||
import binny.{BinaryAttributeStore, BinaryId, BinaryStore}
|
import binny.{BinaryId, BinaryStore}
|
||||||
import doobie.Transactor
|
import doobie.Transactor
|
||||||
|
|
||||||
trait FileRepository[F[_]] {
|
trait FileRepository[F[_]] {
|
||||||
@ -45,17 +45,16 @@ object FileRepository {
|
|||||||
else AttributeStore.empty[F]
|
else AttributeStore.empty[F]
|
||||||
val log = docspell.logging.getLogger[F]
|
val log = docspell.logging.getLogger[F]
|
||||||
val keyFun: FileKey => BinaryId = BinnyUtils.fileKeyToBinaryId
|
val keyFun: FileKey => BinaryId = BinnyUtils.fileKeyToBinaryId
|
||||||
val binStore: BinaryStore[F] = BinnyUtils.binaryStore(cfg, attrStore, ds, log)
|
val binStore: BinaryStore[F] = BinnyUtils.binaryStore(cfg, ds, log)
|
||||||
|
|
||||||
new FileRepositoryImpl[F](cfg, binStore, attrStore, keyFun)
|
new FileRepositoryImpl[F](cfg, binStore, attrStore, keyFun)
|
||||||
}
|
}
|
||||||
|
|
||||||
def getDelegate[F[_]](
|
def getDelegate[F[_]](
|
||||||
repo: FileRepository[F]
|
repo: FileRepository[F]
|
||||||
): Option[(BinaryStore[F], BinaryAttributeStore[F])] =
|
): Option[BinaryStore[F]] =
|
||||||
repo match {
|
repo match {
|
||||||
case n: FileRepositoryImpl[F] =>
|
case n: FileRepositoryImpl[F] =>
|
||||||
Some((n.bs, n.attrStore))
|
Some(n.bs)
|
||||||
|
|
||||||
case _ =>
|
case _ =>
|
||||||
None
|
None
|
||||||
|
@ -30,14 +30,14 @@ final class FileRepositoryImpl[F[_]: Sync](
|
|||||||
|
|
||||||
def findMeta(key: FileKey): F[Option[FileMetadata]] =
|
def findMeta(key: FileKey): F[Option[FileMetadata]] =
|
||||||
attrStore
|
attrStore
|
||||||
.findMeta(keyFun(key))
|
.findMeta(key)
|
||||||
.map(rfm =>
|
.map(rfm =>
|
||||||
FileMetadata(rfm.id, rfm.created, rfm.mimetype, rfm.length, rfm.checksum)
|
FileMetadata(rfm.id, rfm.created, rfm.mimetype, rfm.length, rfm.checksum)
|
||||||
)
|
)
|
||||||
.value
|
.value
|
||||||
|
|
||||||
def delete(key: FileKey): F[Unit] =
|
def delete(key: FileKey): F[Unit] =
|
||||||
bs.delete(keyFun(key))
|
bs.delete(keyFun(key)) *> attrStore.deleteAttr(key).void
|
||||||
|
|
||||||
def save(
|
def save(
|
||||||
collective: Ident,
|
collective: Ident,
|
||||||
@ -48,9 +48,15 @@ final class FileRepositoryImpl[F[_]: Sync](
|
|||||||
in =>
|
in =>
|
||||||
Stream
|
Stream
|
||||||
.eval(randomKey(collective, category))
|
.eval(randomKey(collective, category))
|
||||||
.flatMap(fkey =>
|
.flatMap(fkey => in.through(bs.insertWith(keyFun(fkey))) ++ Stream.emit(fkey))
|
||||||
in.through(bs.insertWith(keyFun(fkey), fhint)) ++ Stream.emit(fkey)
|
.evalTap { key =>
|
||||||
)
|
val bid = keyFun(key)
|
||||||
|
bs.computeAttr(bid, fhint)
|
||||||
|
.run(AttributeName.all)
|
||||||
|
.semiflatMap(attr => attrStore.saveAttr(key, attr))
|
||||||
|
.value
|
||||||
|
.void
|
||||||
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
def randomKey(
|
def randomKey(
|
||||||
|
@ -7,7 +7,7 @@ object Dependencies {
|
|||||||
|
|
||||||
val BcryptVersion = "0.4"
|
val BcryptVersion = "0.4"
|
||||||
val BetterMonadicForVersion = "0.3.1"
|
val BetterMonadicForVersion = "0.3.1"
|
||||||
val BinnyVersion = "0.4.0"
|
val BinnyVersion = "0.6.0"
|
||||||
val CalevVersion = "0.6.3"
|
val CalevVersion = "0.6.3"
|
||||||
val CatsVersion = "2.7.0"
|
val CatsVersion = "2.7.0"
|
||||||
val CatsEffectVersion = "3.3.12"
|
val CatsEffectVersion = "3.3.12"
|
||||||
@ -43,7 +43,7 @@ object Dependencies {
|
|||||||
val PureConfigVersion = "0.17.1"
|
val PureConfigVersion = "0.17.1"
|
||||||
val ScalaJavaTimeVersion = "2.4.0"
|
val ScalaJavaTimeVersion = "2.4.0"
|
||||||
val ScodecBitsVersion = "1.1.31"
|
val ScodecBitsVersion = "1.1.31"
|
||||||
val ScribeVersion = "3.8.3"
|
val ScribeVersion = "3.9.0"
|
||||||
val Slf4jVersion = "1.7.36"
|
val Slf4jVersion = "1.7.36"
|
||||||
val SourcecodeVersion = "0.2.8"
|
val SourcecodeVersion = "0.2.8"
|
||||||
val StanfordNlpVersion = "4.4.0"
|
val StanfordNlpVersion = "4.4.0"
|
||||||
|
Loading…
x
Reference in New Issue
Block a user