Merge pull request #127 from eikek/poll-mailbox

Poll mailbox
This commit is contained in:
eikek 2020-05-20 23:58:55 +02:00 committed by GitHub
commit ba4a4161ac
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
33 changed files with 2754 additions and 62 deletions

View File

@ -48,7 +48,7 @@ object BackendApp {
equipImpl <- OEquipment[F](store) equipImpl <- OEquipment[F](store)
orgImpl <- OOrganization(store) orgImpl <- OOrganization(store)
joexImpl <- OJoex.create(httpClientEc, store) joexImpl <- OJoex.create(httpClientEc, store)
uploadImpl <- OUpload(store, queue, cfg, joexImpl) uploadImpl <- OUpload(store, queue, cfg.files, joexImpl)
nodeImpl <- ONode(store) nodeImpl <- ONode(store)
jobImpl <- OJob(store, joexImpl) jobImpl <- OJob(store, joexImpl)
itemImpl <- OItem(store) itemImpl <- OItem(store)

View File

@ -12,19 +12,29 @@ import docspell.common._
import docspell.store._ import docspell.store._
import docspell.store.records._ import docspell.store.records._
import docspell.store.queries.QMails import docspell.store.queries.QMails
import OMail.{ItemMail, Sent, SmtpSettings} import OMail.{ImapSettings, ItemMail, Sent, SmtpSettings}
trait OMail[F[_]] { trait OMail[F[_]] {
def getSettings(accId: AccountId, nameQ: Option[String]): F[Vector[RUserEmail]] def getSmtpSettings(accId: AccountId, nameQ: Option[String]): F[Vector[RUserEmail]]
def findSettings(accId: AccountId, name: Ident): OptionT[F, RUserEmail] def findSmtpSettings(accId: AccountId, name: Ident): OptionT[F, RUserEmail]
def createSettings(accId: AccountId, data: SmtpSettings): F[AddResult] def createSmtpSettings(accId: AccountId, data: SmtpSettings): F[AddResult]
def updateSettings(accId: AccountId, name: Ident, data: OMail.SmtpSettings): F[Int] def updateSmtpSettings(accId: AccountId, name: Ident, data: OMail.SmtpSettings): F[Int]
def deleteSettings(accId: AccountId, name: Ident): F[Int] def deleteSmtpSettings(accId: AccountId, name: Ident): F[Int]
def getImapSettings(accId: AccountId, nameQ: Option[String]): F[Vector[RUserImap]]
def findImapSettings(accId: AccountId, name: Ident): OptionT[F, RUserImap]
def createImapSettings(accId: AccountId, data: ImapSettings): F[AddResult]
def updateImapSettings(accId: AccountId, name: Ident, data: OMail.ImapSettings): F[Int]
def deleteImapSettings(accId: AccountId, name: Ident): F[Int]
def sendMail(accId: AccountId, name: Ident, m: ItemMail): F[SendResult] def sendMail(accId: AccountId, name: Ident, m: ItemMail): F[SendResult]
@ -103,15 +113,41 @@ object OMail {
) )
} }
case class ImapSettings(
name: Ident,
imapHost: String,
imapPort: Option[Int],
imapUser: Option[String],
imapPassword: Option[Password],
imapSsl: SSLType,
imapCertCheck: Boolean
) {
def toRecord(accId: AccountId) =
RUserImap.fromAccount(
accId,
name,
imapHost,
imapPort,
imapUser,
imapPassword,
imapSsl,
imapCertCheck
)
}
def apply[F[_]: Effect](store: Store[F], emil: Emil[F]): Resource[F, OMail[F]] = def apply[F[_]: Effect](store: Store[F], emil: Emil[F]): Resource[F, OMail[F]] =
Resource.pure[F, OMail[F]](new OMail[F] { Resource.pure[F, OMail[F]](new OMail[F] {
def getSettings(accId: AccountId, nameQ: Option[String]): F[Vector[RUserEmail]] = def getSmtpSettings(
accId: AccountId,
nameQ: Option[String]
): F[Vector[RUserEmail]] =
store.transact(RUserEmail.findByAccount(accId, nameQ)) store.transact(RUserEmail.findByAccount(accId, nameQ))
def findSettings(accId: AccountId, name: Ident): OptionT[F, RUserEmail] = def findSmtpSettings(accId: AccountId, name: Ident): OptionT[F, RUserEmail] =
OptionT(store.transact(RUserEmail.getByName(accId, name))) OptionT(store.transact(RUserEmail.getByName(accId, name)))
def createSettings(accId: AccountId, s: SmtpSettings): F[AddResult] = def createSmtpSettings(accId: AccountId, s: SmtpSettings): F[AddResult] =
(for { (for {
ru <- OptionT(store.transact(s.toRecord(accId).value)) ru <- OptionT(store.transact(s.toRecord(accId).value))
ins = RUserEmail.insert(ru) ins = RUserEmail.insert(ru)
@ -119,7 +155,11 @@ object OMail {
res <- OptionT.liftF(store.add(ins, exists)) res <- OptionT.liftF(store.add(ins, exists))
} yield res).getOrElse(AddResult.Failure(new Exception("User not found"))) } yield res).getOrElse(AddResult.Failure(new Exception("User not found")))
def updateSettings(accId: AccountId, name: Ident, data: SmtpSettings): F[Int] = { def updateSmtpSettings(
accId: AccountId,
name: Ident,
data: SmtpSettings
): F[Int] = {
val op = for { val op = for {
um <- OptionT(RUserEmail.getByName(accId, name)) um <- OptionT(RUserEmail.getByName(accId, name))
ru <- data.toRecord(accId) ru <- data.toRecord(accId)
@ -129,12 +169,43 @@ object OMail {
store.transact(op.value).map(_.getOrElse(0)) store.transact(op.value).map(_.getOrElse(0))
} }
def deleteSettings(accId: AccountId, name: Ident): F[Int] = def deleteSmtpSettings(accId: AccountId, name: Ident): F[Int] =
store.transact(RUserEmail.delete(accId, name)) store.transact(RUserEmail.delete(accId, name))
def getImapSettings(accId: AccountId, nameQ: Option[String]): F[Vector[RUserImap]] =
store.transact(RUserImap.findByAccount(accId, nameQ))
def findImapSettings(accId: AccountId, name: Ident): OptionT[F, RUserImap] =
OptionT(store.transact(RUserImap.getByName(accId, name)))
def createImapSettings(accId: AccountId, data: ImapSettings): F[AddResult] =
(for {
ru <- OptionT(store.transact(data.toRecord(accId).value))
ins = RUserImap.insert(ru)
exists = RUserImap.exists(ru.uid, ru.name)
res <- OptionT.liftF(store.add(ins, exists))
} yield res).getOrElse(AddResult.Failure(new Exception("User not found")))
def updateImapSettings(
accId: AccountId,
name: Ident,
data: OMail.ImapSettings
): F[Int] = {
val op = for {
um <- OptionT(RUserImap.getByName(accId, name))
ru <- data.toRecord(accId)
n <- OptionT.liftF(RUserImap.update(um.id, ru))
} yield n
store.transact(op.value).map(_.getOrElse(0))
}
def deleteImapSettings(accId: AccountId, name: Ident): F[Int] =
store.transact(RUserImap.delete(accId, name))
def sendMail(accId: AccountId, name: Ident, m: ItemMail): F[SendResult] = { def sendMail(accId: AccountId, name: Ident, m: ItemMail): F[SendResult] = {
val getSettings: OptionT[F, RUserEmail] = val getSmtpSettings: OptionT[F, RUserEmail] =
OptionT(store.transact(RUserEmail.getByName(accId, name))) OptionT(store.transact(RUserEmail.getByName(accId, name)))
def createMail(sett: RUserEmail): OptionT[F, Mail[F]] = { def createMail(sett: RUserEmail): OptionT[F, Mail[F]] = {
@ -198,7 +269,7 @@ object OMail {
} }
(for { (for {
mailCfg <- getSettings mailCfg <- getSmtpSettings
mail <- createMail(mailCfg) mail <- createMail(mailCfg)
mid <- OptionT.liftF(sendMail(mailCfg.toMailConfig, mail)) mid <- OptionT.liftF(sendMail(mailCfg.toMailConfig, mail))
res <- mid.traverse(id => OptionT.liftF(storeMail(id, mailCfg))) res <- mid.traverse(id => OptionT.liftF(storeMail(id, mailCfg)))

View File

@ -14,9 +14,17 @@ import org.log4s._
trait OUpload[F[_]] { trait OUpload[F[_]] {
def submit(data: OUpload.UploadData[F], account: AccountId): F[OUpload.UploadResult] def submit(
data: OUpload.UploadData[F],
account: AccountId,
notifyJoex: Boolean
): F[OUpload.UploadResult]
def submit(data: OUpload.UploadData[F], sourceId: Ident): F[OUpload.UploadResult] def submit(
data: OUpload.UploadData[F],
sourceId: Ident,
notifyJoex: Boolean
): F[OUpload.UploadResult]
} }
object OUpload { object OUpload {
@ -52,14 +60,15 @@ object OUpload {
def apply[F[_]: Sync]( def apply[F[_]: Sync](
store: Store[F], store: Store[F],
queue: JobQueue[F], queue: JobQueue[F],
cfg: Config, cfg: Config.Files,
joex: OJoex[F] joex: OJoex[F]
): Resource[F, OUpload[F]] = ): Resource[F, OUpload[F]] =
Resource.pure[F, OUpload[F]](new OUpload[F] { Resource.pure[F, OUpload[F]](new OUpload[F] {
def submit( def submit(
data: OUpload.UploadData[F], data: OUpload.UploadData[F],
account: AccountId account: AccountId,
notifyJoex: Boolean
): F[OUpload.UploadResult] = ): F[OUpload.UploadResult] =
for { for {
files <- data.files.traverse(saveFile).map(_.flatten) files <- data.files.traverse(saveFile).map(_.flatten)
@ -77,13 +86,17 @@ object OUpload {
else Vector(ProcessItemArgs(meta, files.toList)) else Vector(ProcessItemArgs(meta, files.toList))
job <- pred.traverse(_ => makeJobs(args, account, data.priority, data.tracker)) job <- pred.traverse(_ => makeJobs(args, account, data.priority, data.tracker))
_ <- logger.fdebug(s"Storing jobs: $job") _ <- logger.fdebug(s"Storing jobs: $job")
res <- job.traverse(submitJobs) res <- job.traverse(submitJobs(notifyJoex))
_ <- store.transact( _ <- store.transact(
RSource.incrementCounter(data.meta.sourceAbbrev, account.collective) RSource.incrementCounter(data.meta.sourceAbbrev, account.collective)
) )
} yield res.fold(identity, identity) } yield res.fold(identity, identity)
def submit(data: OUpload.UploadData[F], sourceId: Ident): F[OUpload.UploadResult] = def submit(
data: OUpload.UploadData[F],
sourceId: Ident,
notifyJoex: Boolean
): F[OUpload.UploadResult] =
for { for {
sOpt <- sOpt <-
store store
@ -92,20 +105,22 @@ object OUpload {
abbrev = sOpt.map(_.abbrev).toOption.getOrElse(data.meta.sourceAbbrev) abbrev = sOpt.map(_.abbrev).toOption.getOrElse(data.meta.sourceAbbrev)
updata = data.copy(meta = data.meta.copy(sourceAbbrev = abbrev)) updata = data.copy(meta = data.meta.copy(sourceAbbrev = abbrev))
accId = sOpt.map(source => AccountId(source.cid, source.sid)) accId = sOpt.map(source => AccountId(source.cid, source.sid))
result <- accId.traverse(acc => submit(updata, acc)) result <- accId.traverse(acc => submit(updata, acc, notifyJoex))
} yield result.fold(identity, identity) } yield result.fold(identity, identity)
private def submitJobs(jobs: Vector[RJob]): F[OUpload.UploadResult] = private def submitJobs(
notifyJoex: Boolean
)(jobs: Vector[RJob]): F[OUpload.UploadResult] =
for { for {
_ <- logger.fdebug(s"Storing jobs: $jobs") _ <- logger.fdebug(s"Storing jobs: $jobs")
_ <- queue.insertAll(jobs) _ <- queue.insertAll(jobs)
_ <- joex.notifyAllNodes _ <- if (notifyJoex) joex.notifyAllNodes else ().pure[F]
} yield UploadResult.Success } yield UploadResult.Success
private def saveFile(file: File[F]): F[Option[ProcessItemArgs.File]] = private def saveFile(file: File[F]): F[Option[ProcessItemArgs.File]] =
logger.finfo(s"Receiving file $file") *> logger.finfo(s"Receiving file $file") *>
store.bitpeace store.bitpeace
.saveNew(file.data, cfg.files.chunkSize, MimetypeHint(file.name, None), None) .saveNew(file.data, cfg.chunkSize, MimetypeHint(file.name, None), None)
.compile .compile
.lastOrError .lastOrError
.map(fm => Ident.unsafe(fm.id)) .map(fm => Ident.unsafe(fm.id))

View File

@ -11,6 +11,18 @@ import docspell.common._
trait OUserTask[F[_]] { trait OUserTask[F[_]] {
/** Return the settings for the scan-mailbox task of the current user.
* There is at most one such task per user.
*/
def getScanMailbox(account: AccountId): F[UserTask[ScanMailboxArgs]]
/** Updates the scan-mailbox tasks and notifies the joex nodes.
*/
def submitScanMailbox(
account: AccountId,
task: UserTask[ScanMailboxArgs]
): F[Unit]
/** Return the settings for the notify-due-items task of the current /** Return the settings for the notify-due-items task of the current
* user. There is at most one such task per user. * user. There is at most one such task per user.
*/ */
@ -51,6 +63,20 @@ object OUserTask {
_ <- joex.notifyAllNodes _ <- joex.notifyAllNodes
} yield () } yield ()
def getScanMailbox(account: AccountId): F[UserTask[ScanMailboxArgs]] =
store
.getOneByName[ScanMailboxArgs](account, ScanMailboxArgs.taskName)
.getOrElseF(scanMailboxDefault(account))
def submitScanMailbox(
account: AccountId,
task: UserTask[ScanMailboxArgs]
): F[Unit] =
for {
_ <- store.updateOneTask[ScanMailboxArgs](account, task)
_ <- joex.notifyAllNodes
} yield ()
def getNotifyDueItems(account: AccountId): F[UserTask[NotifyDueItemsArgs]] = def getNotifyDueItems(account: AccountId): F[UserTask[NotifyDueItemsArgs]] =
store store
.getOneByName[NotifyDueItemsArgs](account, NotifyDueItemsArgs.taskName) .getOneByName[NotifyDueItemsArgs](account, NotifyDueItemsArgs.taskName)
@ -86,6 +112,27 @@ object OUserTask {
Nil Nil
) )
) )
private def scanMailboxDefault(
account: AccountId
): F[UserTask[ScanMailboxArgs]] =
for {
id <- Ident.randomId[F]
} yield UserTask(
id,
ScanMailboxArgs.taskName,
false,
CalEvent.unsafe("*-*-* 0,12:00"),
ScanMailboxArgs(
account,
Ident.unsafe(""),
Nil,
Some(Duration.hours(12)),
None,
false,
None
)
)
}) })
} }

View File

@ -4,7 +4,7 @@ import cats.implicits._
import scala.concurrent.duration.{FiniteDuration, Duration => SDur} import scala.concurrent.duration.{FiniteDuration, Duration => SDur}
import java.time.{Duration => JDur} import java.time.{Duration => JDur}
import java.util.concurrent.TimeUnit import java.util.concurrent.TimeUnit
import io.circe._
import cats.effect.Sync import cats.effect.Sync
case class Duration(nanos: Long) { case class Duration(nanos: Long) {
@ -13,6 +13,10 @@ case class Duration(nanos: Long) {
def seconds: Long = millis / 1000 def seconds: Long = millis / 1000
def minutes: Long = seconds / 60
def hours: Long = minutes / 60
def toScala: FiniteDuration = def toScala: FiniteDuration =
FiniteDuration(nanos, TimeUnit.NANOSECONDS) FiniteDuration(nanos, TimeUnit.NANOSECONDS)
@ -54,4 +58,10 @@ object Duration {
now <- Timestamp.current[F] now <- Timestamp.current[F]
end = Timestamp.current[F] end = Timestamp.current[F]
} yield end.map(e => Duration.millis(e.toMillis - now.toMillis)) } yield end.map(e => Duration.millis(e.toMillis - now.toMillis))
implicit val jsonEncoder: Encoder[Duration] =
Encoder.encodeLong.contramap(_.millis)
implicit val jsonDecoder: Decoder[Duration] =
Decoder.decodeLong.map(Duration.millis)
} }

View File

@ -96,6 +96,7 @@ object MimeType {
val tiff = image("tiff") val tiff = image("tiff")
val html = text("html") val html = text("html")
val plain = text("plain") val plain = text("plain")
val eml = MimeType("message", "rfc822", Map.empty)
object PdfMatch { object PdfMatch {
def unapply(mt: MimeType): Option[MimeType] = def unapply(mt: MimeType): Option[MimeType] =

View File

@ -0,0 +1,42 @@
package docspell.common
import io.circe._, io.circe.generic.semiauto._
import docspell.common.syntax.all._
/** Arguments to the poll-mailbox task.
*
* This tasks queries user mailboxes and pushes found mails into
* docspell for processing.
*
* If the structure changes, there must be some database migration to
* update or remove the json data of the corresponding task.
*/
case class ScanMailboxArgs(
// the docspell user account
account: AccountId,
// the configured imap connection
imapConnection: Ident,
// what folders to search
folders: List[String],
// only select mails received since then
receivedSince: Option[Duration],
// move submitted mails to another folder
targetFolder: Option[String],
// delete the after submitting (only if targetFolder is None)
deleteMail: Boolean,
// set the direction when submitting
direction: Option[Direction]
)
object ScanMailboxArgs {
val taskName = Ident.unsafe("scan-mailbox")
implicit val jsonEncoder: Encoder[ScanMailboxArgs] =
deriveEncoder[ScanMailboxArgs]
implicit val jsonDecoder: Decoder[ScanMailboxArgs] =
deriveDecoder[ScanMailboxArgs]
def parse(str: String): Either[Throwable, ScanMailboxArgs] =
str.parseJsonAs[ScanMailboxArgs]
}

View File

@ -31,6 +31,12 @@ docspell.joex {
password = "" password = ""
} }
# Enable or disable debugging for e-mail related functionality. This
# applies to both sending and receiving mails. For security reasons
# logging is not very extensive on authentication failures. Setting
# this to true, results in a lot of data printed to stdout.
mail-debug = false
send-mail { send-mail {
# This is used as the List-Id e-mail header when mails are sent # This is used as the List-Id e-mail header when mails are sent
# from docspell to its users (example: for notification mails). It # from docspell to its users (example: for notification mails). It
@ -90,6 +96,32 @@ docspell.joex {
wakeup-period = "10 minutes" wakeup-period = "10 minutes"
} }
# Configuration for the user-tasks.
user-tasks {
# Allows to import e-mails by scanning a mailbox.
scan-mailbox {
# A limit of how many folders to scan through. If a user
# configures more than this, only upto this limit folders are
# scanned and a warning is logged.
max-folders = 50
# How many mails (headers only) to retrieve in one chunk.
#
# If this is greater than `max-mails' it is set automatically to
# the value of `max-mails'.
mail-chunk-size = 50
# A limit on how many mails to process in one job run. This is
# meant to avoid too heavy resource allocation to one
# user/collective.
#
# If more than this number of mails is encountered, a warning is
# logged.
max-mails = 500
}
}
# Docspell uses periodic house keeping tasks, like cleaning expired # Docspell uses periodic house keeping tasks, like cleaning expired
# invites, that can be configured here. # invites, that can be configured here.
house-keeping { house-keeping {
@ -308,4 +340,28 @@ docspell.joex {
working-dir = ${java.io.tmpdir}"/docspell-convert" working-dir = ${java.io.tmpdir}"/docspell-convert"
} }
} }
# The same section is also present in the rest-server config. It is
# used when submitting files into the job queue for processing.
#
# Currently, these settings may affect memory usage of all nodes, so
# it should be the same on all nodes.
files {
# Defines the chunk size (in bytes) used to store the files.
# This will affect the memory footprint when uploading and
# downloading files. At most this amount is loaded into RAM for
# down- and uploading.
#
# It also defines the chunk size used for the blobs inside the
# database.
chunk-size = 524288
# The file content types that are considered valid. Docspell
# will only pass these files to processing. The processing code
# itself has also checks for which files are supported and which
# not. This affects the uploading part and can be used to
# restrict file types that should be handed over to processing.
# By default all files are allowed.
valid-mime-types = [ ]
}
} }

View File

@ -7,6 +7,7 @@ import docspell.store.JdbcConfig
import docspell.convert.ConvertConfig import docspell.convert.ConvertConfig
import docspell.extract.ExtractConfig import docspell.extract.ExtractConfig
import docspell.joex.hk.HouseKeepingConfig import docspell.joex.hk.HouseKeepingConfig
import docspell.backend.Config.Files
case class Config( case class Config(
appId: Ident, appId: Ident,
@ -15,13 +16,22 @@ case class Config(
jdbc: JdbcConfig, jdbc: JdbcConfig,
scheduler: SchedulerConfig, scheduler: SchedulerConfig,
periodicScheduler: PeriodicSchedulerConfig, periodicScheduler: PeriodicSchedulerConfig,
userTasks: Config.UserTasks,
houseKeeping: HouseKeepingConfig, houseKeeping: HouseKeepingConfig,
extraction: ExtractConfig, extraction: ExtractConfig,
textAnalysis: TextAnalysisConfig, textAnalysis: TextAnalysisConfig,
convert: ConvertConfig, convert: ConvertConfig,
sendMail: MailSendConfig sendMail: MailSendConfig,
files: Files,
mailDebug: Boolean
) )
object Config { object Config {
case class Bind(address: String, port: Int) case class Bind(address: String, port: Int)
case class ScanMailbox(maxFolders: Int, mailChunkSize: Int, maxMails: Int) {
def mailBatchSize: Int =
math.min(mailChunkSize, maxMails)
}
case class UserTasks(scanMailbox: ScanMailbox)
} }

View File

@ -4,14 +4,15 @@ import cats.implicits._
import cats.effect._ import cats.effect._
import emil.javamail._ import emil.javamail._
import docspell.common._ import docspell.common._
import docspell.backend.ops._
import docspell.joex.hk._ import docspell.joex.hk._
import docspell.joex.notify._ import docspell.joex.notify._
import docspell.joex.scanmailbox._
import docspell.joex.process.ItemHandler import docspell.joex.process.ItemHandler
import docspell.joex.scheduler._ import docspell.joex.scheduler._
import docspell.joexapi.client.JoexClient import docspell.joexapi.client.JoexClient
import docspell.store.Store import docspell.store.Store
import docspell.store.queue._ import docspell.store.queue._
import docspell.backend.ops.ONode
import docspell.store.records.RJobLog import docspell.store.records.RJobLog
import fs2.concurrent.SignallingRef import fs2.concurrent.SignallingRef
import scala.concurrent.ExecutionContext import scala.concurrent.ExecutionContext
@ -67,6 +68,10 @@ object JoexAppImpl {
queue <- JobQueue(store) queue <- JobQueue(store)
pstore <- PeriodicTaskStore.create(store) pstore <- PeriodicTaskStore.create(store)
nodeOps <- ONode(store) nodeOps <- ONode(store)
joex <- OJoex(client, store)
upload <- OUpload(store, queue, cfg.files, joex)
javaEmil =
JavaMailEmil(blocker, Settings.defaultSettings.copy(debug = cfg.mailDebug))
sch <- SchedulerBuilder(cfg.scheduler, blocker, store) sch <- SchedulerBuilder(cfg.scheduler, blocker, store)
.withQueue(queue) .withQueue(queue)
.withTask( .withTask(
@ -79,10 +84,17 @@ object JoexAppImpl {
.withTask( .withTask(
JobTask.json( JobTask.json(
NotifyDueItemsArgs.taskName, NotifyDueItemsArgs.taskName,
NotifyDueItemsTask[F](cfg.sendMail, JavaMailEmil(blocker)), NotifyDueItemsTask[F](cfg.sendMail, javaEmil),
NotifyDueItemsTask.onCancel[F] NotifyDueItemsTask.onCancel[F]
) )
) )
.withTask(
JobTask.json(
ScanMailboxArgs.taskName,
ScanMailboxTask[F](cfg.userTasks.scanMailbox, javaEmil, upload, joex),
ScanMailboxTask.onCancel[F]
)
)
.withTask( .withTask(
JobTask.json( JobTask.json(
HouseKeepingTask.taskName, HouseKeepingTask.taskName,

View File

@ -7,6 +7,7 @@ import docspell.common._
import docspell.store.queries.QItem import docspell.store.queries.QItem
import docspell.joex.notify.YamuscaConverter._ import docspell.joex.notify.YamuscaConverter._
/** The context for rendering the e-mail template. */
case class MailContext( case class MailContext(
items: List[MailContext.ItemData], items: List[MailContext.ItemData],
more: Boolean, more: Boolean,

View File

@ -0,0 +1,288 @@
package docspell.joex.scanmailbox
import fs2._
import cats.implicits._
import cats.effect._
import emil.{MimeType => _, _}
import emil.javamail.syntax._
import emil.SearchQuery.{All, ReceivedDate}
import docspell.common._
import docspell.backend.ops.{OJoex, OUpload}
import docspell.store.records._
import docspell.joex.Config
import docspell.joex.scheduler.{Context, Task}
import docspell.store.queries.QOrganization
import cats.data.Kleisli
import cats.data.NonEmptyList
import cats.data.OptionT
object ScanMailboxTask {
val maxItems: Long = 7
type Args = ScanMailboxArgs
def apply[F[_]: Sync](
cfg: Config.ScanMailbox,
emil: Emil[F],
upload: OUpload[F],
joex: OJoex[F]
): Task[F, Args, Unit] =
Task { ctx =>
for {
_ <- ctx.logger.info(
s"Start importing mails for user ${ctx.args.account.user.id}"
)
mailCfg <- getMailSettings(ctx)
folders = ctx.args.folders.mkString(", ")
userId = ctx.args.account.user
imapConn = ctx.args.imapConnection
_ <- ctx.logger.info(
s"Reading mails for user ${userId.id} from ${imapConn.id}/${folders}"
)
_ <- importMails(cfg, mailCfg, emil, upload, joex, ctx)
} yield ()
}
def onCancel[F[_]: Sync]: Task[F, ScanMailboxArgs, Unit] =
Task.log(_.warn("Cancelling scan-mailbox task"))
def getMailSettings[F[_]: Sync](ctx: Context[F, Args]): F[RUserImap] =
ctx.store
.transact(RUserImap.getByName(ctx.args.account, ctx.args.imapConnection))
.flatMap {
case Some(c) => c.pure[F]
case None =>
Sync[F].raiseError(
new Exception(
s"No imap configuration found for: ${ctx.args.imapConnection.id}"
)
)
}
def importMails[F[_]: Sync](
cfg: Config.ScanMailbox,
mailCfg: RUserImap,
theEmil: Emil[F],
upload: OUpload[F],
joex: OJoex[F],
ctx: Context[F, Args]
): F[Unit] = {
val mailer = theEmil(mailCfg.toMailConfig)
val impl = new Impl[F](cfg, ctx)
val inFolders = ctx.args.folders.take(cfg.maxFolders)
val getInitialInput =
for {
_ <-
if (inFolders.size != ctx.args.folders.size)
ctx.logger.warn(
s"More than ${cfg.maxFolders} submitted. Only first ${cfg.maxFolders} will be scanned."
)
else ().pure[F]
} yield inFolders
def processFolder(acc: ScanResult, name: String): F[ScanResult] =
if (acc.noneLeft(name)) acc.pure[F]
else
mailer
.run(impl.handleFolder(theEmil.access, upload)(name))
.map(_ ++ acc)
Stream
.eval(getInitialInput)
.flatMap(Stream.emits)
.repeat
.evalScan(ScanResult.empty)(processFolder)
.takeThrough(result =>
result.processed < cfg.maxMails && result.someLeft(inFolders.size)
)
.lastOr(ScanResult.empty)
.evalMap { sr =>
joex.notifyAllNodes *>
(if (sr.processed >= cfg.maxMails)
ctx.logger.warn(
s"Reached server maximum of ${cfg.maxMails} processed mails. Processed ${sr.processed} mails."
)
else
ctx.logger
.info(s"Stopped after processing ${sr.processed} mails"))
}
.compile
.drain
}
case class ScanResult(folders: List[(String, Int)], processed: Int) {
def ++(sr: ScanResult): ScanResult = {
val fs = (folders ++ sr.folders).sortBy(_._2).distinctBy(_._1)
ScanResult(fs, processed + sr.processed)
}
def noneLeft(name: String): Boolean =
folders.find(_._1 == name).exists(_._2 <= 0)
def someLeft(inputFolders: Int) =
ScanResult.empty == this || folders.exists(_._2 > 0) || inputFolders > folders.size
}
object ScanResult {
val empty = ScanResult(Nil, 0)
def apply(folder: String, processed: Int, left: Int): ScanResult =
ScanResult(List(folder -> left), processed)
}
final private class Impl[F[_]: Sync](cfg: Config.ScanMailbox, ctx: Context[F, Args]) {
def handleFolder[C](a: Access[F, C], upload: OUpload[F])(
name: String
): MailOp[F, C, ScanResult] =
for {
_ <- Kleisli.liftF(ctx.logger.info(s"Processing folder $name"))
folder <- requireFolder(a)(name)
search <- searchMails(a)(folder)
headers <- Kleisli.liftF(filterMessageIds(search.mails))
_ <- headers.traverse(handleOne(a, upload))
} yield ScanResult(name, search.mails.size, search.count - search.mails.size)
def requireFolder[C](a: Access[F, C])(name: String): MailOp[F, C, MailFolder] =
if ("INBOX".equalsIgnoreCase(name)) a.getInbox
else //TODO resolve sub-folders
a.findFolder(None, name)
.map(_.toRight(new Exception(s"Folder '$name' not found")))
.mapF(_.rethrow)
def searchMails[C](
a: Access[F, C]
)(folder: MailFolder): MailOp[F, C, SearchResult[MailHeader]] = {
val q = ctx.args.receivedSince match {
case Some(d) =>
Timestamp.current[F].map(now => ReceivedDate >= now.minus(d).value)
case None => All.pure[F]
}
for {
_ <- Kleisli.liftF(
ctx.logger.debug(
s"Searching next ${cfg.mailBatchSize} mails in ${folder.name}."
)
)
query <- Kleisli.liftF(q)
mails <- a.search(folder, cfg.mailBatchSize)(query)
_ <- Kleisli.liftF(
ctx.logger.debug(
s"Found ${mails.count} mails in folder. Reading first ${mails.mails.size}"
)
)
} yield mails
}
def filterMessageIds(headers: Vector[MailHeader]): F[Vector[MailHeader]] =
NonEmptyList.fromFoldable(headers.flatMap(_.messageId)) match {
case Some(nl) =>
for {
archives <- ctx.store.transact(
RAttachmentArchive
.findByMessageIdAndCollective(nl, ctx.args.account.collective)
)
existing = archives.flatMap(_.messageId).toSet
mails = headers.filterNot(mh => mh.messageId.forall(existing.contains))
_ <- headers.size - mails.size match {
case 0 => ().pure[F]
case n =>
ctx.logger.info(s"Excluded $n mails since items for them already exist.")
}
} yield mails
case None =>
headers.pure[F]
}
def getDirection(mh: MailHeader): F[Direction] = {
val out: OptionT[F, Direction] =
for {
from <- OptionT.fromOption[F](mh.from)
_ <- OptionT(
ctx.store.transact(
QOrganization
.findPersonByContact(
ctx.args.account.collective,
from.address,
Some(ContactKind.Email),
Some(true)
)
.take(1)
.compile
.last
)
)
} yield Direction.Outgoing
OptionT
.fromOption[F](ctx.args.direction)
.orElse(out)
.getOrElse(Direction.Incoming)
}
def postHandle[C](a: Access[F, C])(mh: MailHeader): MailOp[F, C, Unit] =
ctx.args.targetFolder match {
case Some(tf) =>
a.getOrCreateFolder(None, tf).flatMap(folder => a.moveMail(mh, folder))
case None if ctx.args.deleteMail =>
a.deleteMail(mh).flatMapF { r =>
if (r.count == 0)
ctx.logger.warn(s"Mail '${mh.subject}' could not be deleted")
else ().pure[F]
}
case None =>
MailOp.pure(())
}
def submitMail(upload: OUpload[F])(mail: Mail[F]): F[OUpload.UploadResult] = {
val file = OUpload.File(
Some(mail.header.subject + ".eml"),
Some(MimeType.eml),
mail.toByteStream
)
for {
_ <- ctx.logger.debug(s"Submitting mail '${mail.header.subject}'")
dir <- getDirection(mail.header)
meta = OUpload.UploadMeta(
Some(dir),
s"mailbox-${ctx.args.account.user.id}",
Seq.empty
)
data = OUpload.UploadData(
multiple = false,
meta = meta,
files = Vector(file),
priority = Priority.Low,
tracker = None
)
res <- upload.submit(data, ctx.args.account, false)
} yield res
}
def handleOne[C](a: Access[F, C], upload: OUpload[F])(
mh: MailHeader
): MailOp[F, C, Unit] =
for {
mail <- a.loadMail(mh)
res <- mail match {
case Some(m) =>
Kleisli.liftF(submitMail(upload)(m).attempt)
case None =>
MailOp.pure[F, C, Either[Throwable, OUpload.UploadResult]](
Either.left(new Exception(s"Mail not found"))
)
}
_ <- res.fold(
ex =>
Kleisli.liftF(
ctx.logger.warn(s"Error submitting '${mh.subject}': ${ex.getMessage}")
),
_ => postHandle(a)(mh)
)
} yield ()
}
}

View File

@ -1414,7 +1414,7 @@ paths:
application/json: application/json:
schema: schema:
$ref: "#/components/schemas/BasicResult" $ref: "#/components/schemas/BasicResult"
/sec/email/settings: /sec/email/settings/smtp:
get: get:
tags: [ E-Mail ] tags: [ E-Mail ]
summary: List email settings for current user. summary: List email settings for current user.
@ -1456,7 +1456,7 @@ paths:
application/json: application/json:
schema: schema:
$ref: "#/components/schemas/BasicResult" $ref: "#/components/schemas/BasicResult"
/sec/email/settings/{name}: /sec/email/settings/smtp/{name}:
parameters: parameters:
- $ref: "#/components/parameters/name" - $ref: "#/components/parameters/name"
get: get:
@ -1507,6 +1507,99 @@ paths:
application/json: application/json:
schema: schema:
$ref: "#/components/schemas/BasicResult" $ref: "#/components/schemas/BasicResult"
/sec/email/settings/imap:
get:
tags: [ E-Mail ]
summary: List email settings for current user.
description: |
List all available e-mail settings for the current user.
E-Mail settings specify imap connections that can be used to
retrieve e-mails.
Multiple e-mail settings can be specified, they are
distinguished by their `name`. The query `q` parameter does a
simple substring search in the connection name.
security:
- authTokenHeader: []
parameters:
- $ref: "#/components/parameters/q"
responses:
200:
description: Ok
content:
application/json:
schema:
$ref: "#/components/schemas/ImapSettingsList"
post:
tags: [ E-Mail ]
summary: Create new email settings
description: |
Create new e-mail settings.
security:
- authTokenHeader: []
requestBody:
content:
application/json:
schema:
$ref: "#/components/schemas/ImapSettings"
responses:
200:
description: Ok
content:
application/json:
schema:
$ref: "#/components/schemas/BasicResult"
/sec/email/settings/imap/{name}:
parameters:
- $ref: "#/components/parameters/name"
get:
tags: [ E-Mail ]
summary: Return specific email settings by name.
description: |
Return the stored e-mail settings for the given connection
name.
security:
- authTokenHeader: []
responses:
200:
description: Ok
content:
application/json:
schema:
$ref: "#/components/schemas/ImapSettings"
put:
tags: [ E-Mail ]
summary: Change specific email settings.
description: |
Changes all settings for the connection with the given `name`.
security:
- authTokenHeader: []
requestBody:
content:
application/json:
schema:
$ref: "#/components/schemas/ImapSettings"
responses:
200:
description: Ok
content:
application/json:
schema:
$ref: "#/components/schemas/BasicResult"
delete:
tags: [ E-Mail ]
summary: Delete e-mail settings.
description: |
Deletes the e-mail settings with the specified `name`.
security:
- authTokenHeader: []
responses:
200:
description: Ok
content:
application/json:
schema:
$ref: "#/components/schemas/BasicResult"
/sec/email/send/{name}/{id}: /sec/email/send/{name}/{id}:
post: post:
@ -1662,8 +1755,152 @@ paths:
schema: schema:
$ref: "#/components/schemas/BasicResult" $ref: "#/components/schemas/BasicResult"
/sec/usertask/scanmailbox:
get:
tags: [ User Tasks ]
summary: Get settings for "Scan Mailbox" task
description: |
Return the current settings for the scan mailbox task of the
authenticated user. Users can periodically fetch mails to be
imported into docspell.
security:
- authTokenHeader: []
responses:
200:
description: Ok
content:
application/json:
schema:
$ref: "#/components/schemas/ScanMailboxSettings"
post:
tags: [ User Tasks ]
summary: Change current settings for "Scan Mailbox" task
description: |
Change the current settings for the scan-mailbox task of the
authenticated user.
security:
- authTokenHeader: []
requestBody:
content:
application/json:
schema:
$ref: "#/components/schemas/ScanMailboxSettings"
responses:
200:
description: Ok
content:
application/json:
schema:
$ref: "#/components/schemas/BasicResult"
/sec/usertask/scanmailbox/startonce:
post:
tags: [ User Tasks ]
summary: Start the "Scan Mailbox" task once
description: |
Starts the scan-mailbox task just once, discarding the
schedule and not updating the periodic task.
security:
- authTokenHeader: []
requestBody:
content:
application/json:
schema:
$ref: "#/components/schemas/ScanMailboxSettings"
responses:
200:
description: Ok
content:
application/json:
schema:
$ref: "#/components/schemas/BasicResult"
components: components:
schemas: schemas:
ScanMailboxSettings:
description: |
Settings for the scan mailbox task.
required:
- id
- enabled
- imapConnection
- schedule
- folders
- deleteMail
properties:
id:
type: string
format: ident
enabled:
type: boolean
imapConnection:
type: string
format: ident
folders:
type: array
items:
type: string
schedule:
type: string
format: calevent
receivedSinceHours:
type: integer
format: int32
description: |
Look only for mails newer than `receivedSinceHours' hours.
targetFolder:
type: string
description: |
The folder to move all mails into that have been
successfully submitted to docspell.
deleteMail:
type: boolean
description: |
Whether to delete all successfully imported mails. This
only applies, if `targetFolder' is not set.
direction:
type: string
format: direction
description: |
The direction to apply to items resulting from importing
mails. If not set, the value is guessed based on the from
and to mail headers and your address book.
ImapSettingsList:
description: |
A list of user email settings.
required:
- items
properties:
items:
type: array
items:
$ref: "#/components/schemas/ImapSettings"
ImapSettings:
description: |
IMAP settings for sending mail.
required:
- name
- imapHost
- from
- sslType
- ignoreCertificates
properties:
name:
type: string
format: ident
imapHost:
type: string
imapPort:
type: integer
format: int32
imapUser:
type: string
imapPassword:
type: string
format: password
sslType:
type: string
ignoreCertificates:
type: boolean
CalEventCheckResult: CalEventCheckResult:
description: | description: |
The result of checking a calendar event string. The result of checking a calendar event string.

View File

@ -76,6 +76,7 @@ object RestServer {
"email/settings" -> MailSettingsRoutes(restApp.backend, token), "email/settings" -> MailSettingsRoutes(restApp.backend, token),
"email/sent" -> SentMailRoutes(restApp.backend, token), "email/sent" -> SentMailRoutes(restApp.backend, token),
"usertask/notifydueitems" -> NotifyDueItemsRoutes(cfg, restApp.backend, token), "usertask/notifydueitems" -> NotifyDueItemsRoutes(cfg, restApp.backend, token),
"usertask/scanmailbox" -> ScanMailboxRoutes(restApp.backend, token),
"calevent/check" -> CalEventCheckRoutes() "calevent/check" -> CalEventCheckRoutes()
) )

View File

@ -15,7 +15,7 @@ import docspell.backend.auth.AuthToken
import docspell.backend.ops.OMail import docspell.backend.ops.OMail
import docspell.common._ import docspell.common._
import docspell.restapi.model._ import docspell.restapi.model._
import docspell.store.records.RUserEmail import docspell.store.records.{RUserEmail, RUserImap}
import docspell.restserver.conv.Conversions import docspell.restserver.conv.Conversions
import docspell.restserver.http4s.QueryParam import docspell.restserver.http4s.QueryParam
@ -26,25 +26,38 @@ object MailSettingsRoutes {
import dsl._ import dsl._
HttpRoutes.of { HttpRoutes.of {
case GET -> Root :? QueryParam.QueryOpt(q) => case GET -> Root / "smtp" :? QueryParam.QueryOpt(q) =>
for { for {
list <- backend.mail.getSettings(user.account, q.map(_.q)) list <- backend.mail.getSmtpSettings(user.account, q.map(_.q))
res = list.map(convert) res = list.map(convert)
resp <- Ok(EmailSettingsList(res.toList)) resp <- Ok(EmailSettingsList(res.toList))
} yield resp } yield resp
case GET -> Root / Ident(name) => case GET -> Root / "imap" :? QueryParam.QueryOpt(q) =>
for {
list <- backend.mail.getImapSettings(user.account, q.map(_.q))
res = list.map(convert)
resp <- Ok(ImapSettingsList(res.toList))
} yield resp
case GET -> Root / "smtp" / Ident(name) =>
(for { (for {
ems <- backend.mail.findSettings(user.account, name) ems <- backend.mail.findSmtpSettings(user.account, name)
resp <- OptionT.liftF(Ok(convert(ems))) resp <- OptionT.liftF(Ok(convert(ems)))
} yield resp).getOrElseF(NotFound()) } yield resp).getOrElseF(NotFound())
case req @ POST -> Root => case GET -> Root / "imap" / Ident(name) =>
(for {
ems <- backend.mail.findImapSettings(user.account, name)
resp <- OptionT.liftF(Ok(convert(ems)))
} yield resp).getOrElseF(NotFound())
case req @ POST -> Root / "smtp" =>
(for { (for {
in <- OptionT.liftF(req.as[EmailSettings]) in <- OptionT.liftF(req.as[EmailSettings])
ru = makeSettings(in) ru = makeSmtpSettings(in)
up <- OptionT.liftF( up <- OptionT.liftF(
ru.traverse(r => backend.mail.createSettings(user.account, r)) ru.traverse(r => backend.mail.createSmtpSettings(user.account, r))
) )
resp <- OptionT.liftF( resp <- OptionT.liftF(
Ok( Ok(
@ -56,12 +69,29 @@ object MailSettingsRoutes {
) )
} yield resp).getOrElseF(NotFound()) } yield resp).getOrElseF(NotFound())
case req @ PUT -> Root / Ident(name) => case req @ POST -> Root / "imap" =>
(for {
in <- OptionT.liftF(req.as[ImapSettings])
ru = makeImapSettings(in)
up <- OptionT.liftF(
ru.traverse(r => backend.mail.createImapSettings(user.account, r))
)
resp <- OptionT.liftF(
Ok(
up.fold(
err => BasicResult(false, err),
ar => Conversions.basicResult(ar, "Mail settings stored.")
)
)
)
} yield resp).getOrElseF(NotFound())
case req @ PUT -> Root / "smtp" / Ident(name) =>
(for { (for {
in <- OptionT.liftF(req.as[EmailSettings]) in <- OptionT.liftF(req.as[EmailSettings])
ru = makeSettings(in) ru = makeSmtpSettings(in)
up <- OptionT.liftF( up <- OptionT.liftF(
ru.traverse(r => backend.mail.updateSettings(user.account, name, r)) ru.traverse(r => backend.mail.updateSmtpSettings(user.account, name, r))
) )
resp <- OptionT.liftF( resp <- OptionT.liftF(
Ok( Ok(
@ -75,16 +105,43 @@ object MailSettingsRoutes {
) )
} yield resp).getOrElseF(NotFound()) } yield resp).getOrElseF(NotFound())
case DELETE -> Root / Ident(name) => case req @ PUT -> Root / "imap" / Ident(name) =>
(for {
in <- OptionT.liftF(req.as[ImapSettings])
ru = makeImapSettings(in)
up <- OptionT.liftF(
ru.traverse(r => backend.mail.updateImapSettings(user.account, name, r))
)
resp <- OptionT.liftF(
Ok(
up.fold(
err => BasicResult(false, err),
n =>
if (n > 0) BasicResult(true, "Mail settings stored.")
else BasicResult(false, "Mail settings could not be saved")
)
)
)
} yield resp).getOrElseF(NotFound())
case DELETE -> Root / "smtp" / Ident(name) =>
for { for {
n <- backend.mail.deleteSettings(user.account, name) n <- backend.mail.deleteSmtpSettings(user.account, name)
resp <- Ok(
if (n > 0) BasicResult(true, "Mail settings removed")
else BasicResult(false, "Mail settings could not be removed")
)
} yield resp
case DELETE -> Root / "imap" / Ident(name) =>
for {
n <- backend.mail.deleteImapSettings(user.account, name)
resp <- Ok( resp <- Ok(
if (n > 0) BasicResult(true, "Mail settings removed") if (n > 0) BasicResult(true, "Mail settings removed")
else BasicResult(false, "Mail settings could not be removed") else BasicResult(false, "Mail settings could not be removed")
) )
} yield resp } yield resp
} }
} }
def convert(ru: RUserEmail): EmailSettings = def convert(ru: RUserEmail): EmailSettings =
@ -100,7 +157,18 @@ object MailSettingsRoutes {
!ru.smtpCertCheck !ru.smtpCertCheck
) )
def makeSettings(ems: EmailSettings): Either[String, OMail.SmtpSettings] = { def convert(ru: RUserImap): ImapSettings =
ImapSettings(
ru.name,
ru.imapHost,
ru.imapPort,
ru.imapUser,
ru.imapPassword,
ru.imapSsl.name,
!ru.imapCertCheck
)
def makeSmtpSettings(ems: EmailSettings): Either[String, OMail.SmtpSettings] = {
def readMail(str: String): Either[String, MailAddress] = def readMail(str: String): Either[String, MailAddress] =
MailAddress.parse(str).left.map(err => s"E-Mail address '$str' invalid: $err") MailAddress.parse(str).left.map(err => s"E-Mail address '$str' invalid: $err")
@ -122,6 +190,18 @@ object MailSettingsRoutes {
from, from,
repl repl
) )
} }
def makeImapSettings(ims: ImapSettings): Either[String, OMail.ImapSettings] =
for {
sslt <- SSLType.fromString(ims.sslType)
} yield OMail.ImapSettings(
ims.name,
ims.imapHost,
ims.imapPort,
ims.imapUser,
ims.imapPassword,
sslt,
!ims.ignoreCertificates
)
} }

View File

@ -91,7 +91,7 @@ object NotifyDueItemsRoutes {
texc <- backend.tag.loadAll(task.args.tagsExclude) texc <- backend.tag.loadAll(task.args.tagsExclude)
conn <- conn <-
backend.mail backend.mail
.getSettings(account, None) .getSmtpSettings(account, None)
.map( .map(
_.find(_.name == task.args.smtpConnection) _.find(_.name == task.args.smtpConnection)
.map(_.name) .map(_.name)

View File

@ -0,0 +1,103 @@
package docspell.restserver.routes
import cats.effect._
import cats.implicits._
import org.http4s._
import org.http4s.dsl.Http4sDsl
import org.http4s.circe.CirceEntityEncoder._
import org.http4s.circe.CirceEntityDecoder._
import docspell.backend.BackendApp
import docspell.backend.auth.AuthToken
import docspell.common._
import docspell.restapi.model._
import docspell.store.usertask._
import docspell.restserver.conv.Conversions
object ScanMailboxRoutes {
def apply[F[_]: Effect](
backend: BackendApp[F],
user: AuthToken
): HttpRoutes[F] = {
val dsl = new Http4sDsl[F] {}
val ut = backend.userTask
import dsl._
HttpRoutes.of {
case req @ POST -> Root / "startonce" =>
for {
data <- req.as[ScanMailboxSettings]
task = makeTask(user.account, data)
res <-
ut.executeNow(user.account, task)
.attempt
.map(Conversions.basicResult(_, "Submitted successfully."))
resp <- Ok(res)
} yield resp
case GET -> Root =>
for {
task <- ut.getScanMailbox(user.account)
res <- taskToSettings(user.account, backend, task)
resp <- Ok(res)
} yield resp
case req @ POST -> Root =>
for {
data <- req.as[ScanMailboxSettings]
task = makeTask(user.account, data)
res <-
ut.submitScanMailbox(user.account, task)
.attempt
.map(Conversions.basicResult(_, "Saved successfully."))
resp <- Ok(res)
} yield resp
}
}
def makeTask(
user: AccountId,
settings: ScanMailboxSettings
): UserTask[ScanMailboxArgs] =
UserTask(
settings.id,
ScanMailboxArgs.taskName,
settings.enabled,
settings.schedule,
ScanMailboxArgs(
user,
settings.imapConnection,
settings.folders,
settings.receivedSinceHours.map(_.toLong).map(Duration.hours),
settings.targetFolder,
settings.deleteMail,
settings.direction
)
)
def taskToSettings[F[_]: Sync](
account: AccountId,
backend: BackendApp[F],
task: UserTask[ScanMailboxArgs]
): F[ScanMailboxSettings] =
for {
conn <-
backend.mail
.getImapSettings(account, None)
.map(
_.find(_.name == task.args.imapConnection)
.map(_.name)
)
} yield ScanMailboxSettings(
task.id,
task.enabled,
conn.getOrElse(Ident.unsafe("")),
task.args.folders, //folders
task.timer,
task.args.receivedSince.map(_.hours.toInt),
task.args.targetFolder,
task.args.deleteMail,
task.args.direction
)
}

View File

@ -37,7 +37,7 @@ object UploadRoutes {
Priority.High, Priority.High,
cfg.backend.files.validMimeTypes cfg.backend.files.validMimeTypes
) )
result <- backend.upload.submit(updata, user.account) result <- backend.upload.submit(updata, user.account, true)
res <- Ok(basicResult(result)) res <- Ok(basicResult(result))
} yield res } yield res
@ -61,7 +61,7 @@ object UploadRoutes {
Priority.Low, Priority.Low,
cfg.backend.files.validMimeTypes cfg.backend.files.validMimeTypes
) )
result <- backend.upload.submit(updata, id) result <- backend.upload.submit(updata, id, true)
res <- Ok(basicResult(result)) res <- Ok(basicResult(result))
} yield res } yield res

View File

@ -0,0 +1,14 @@
CREATE TABLE `userimap` (
`id` varchar(254) not null primary key,
`uid` varchar(254) not null,
`name` varchar(254) not null,
`imap_host` varchar(254) not null,
`imap_port` int,
`imap_user` varchar(254),
`imap_password` varchar(254),
`imap_ssl` varchar(254) not null,
`imap_certcheck` boolean not null,
`created` timestamp not null,
unique (`uid`, `name`),
foreign key (`uid`) references `user_`(`uid`)
);

View File

@ -0,0 +1,14 @@
CREATE TABLE "userimap" (
"id" varchar(254) not null primary key,
"uid" varchar(254) not null,
"name" varchar(254) not null,
"imap_host" varchar(254) not null,
"imap_port" int,
"imap_user" varchar(254),
"imap_password" varchar(254),
"imap_ssl" varchar(254) not null,
"imap_certcheck" boolean not null,
"created" timestamp not null,
unique ("uid", "name"),
foreign key ("uid") references "user_"("uid")
);

View File

@ -2,6 +2,7 @@ package docspell.store.impl
import doobie._, doobie.implicits._ import doobie._, doobie.implicits._
import docspell.store.impl.DoobieSyntax._ import docspell.store.impl.DoobieSyntax._
import cats.data.NonEmptyList
case class Column(name: String, ns: String = "", alias: String = "") { case class Column(name: String, ns: String = "", alias: String = "") {
@ -46,6 +47,9 @@ case class Column(name: String, ns: String = "", alias: String = "") {
def isIn(values: Seq[Fragment]): Fragment = def isIn(values: Seq[Fragment]): Fragment =
f ++ fr"IN (" ++ commas(values) ++ fr")" f ++ fr"IN (" ++ commas(values) ++ fr")"
def isIn[A: Put](values: NonEmptyList[A]): Fragment =
isIn(values.map(a => sql"$a").toList)
def isIn(frag: Fragment): Fragment = def isIn(frag: Fragment): Fragment =
f ++ fr"IN (" ++ frag ++ fr")" f ++ fr"IN (" ++ frag ++ fr")"

View File

@ -86,6 +86,31 @@ object QOrganization {
}) })
} }
def findPersonByContact(
coll: Ident,
value: String,
ck: Option[ContactKind],
concerning: Option[Boolean]
): Stream[ConnectionIO, RPerson] = {
val pColl = PC.cid.prefix("p")
val pConc = PC.concerning.prefix("p")
val pId = PC.pid.prefix("p")
val cPers = RContact.Columns.personId.prefix("c")
val cVal = RContact.Columns.value.prefix("c")
val cKind = RContact.Columns.kind.prefix("c")
val from = RPerson.table ++ fr"p INNER JOIN" ++
RContact.table ++ fr"c ON" ++ cPers.is(pId)
val q = Seq(
cVal.lowerLike(s"%${value.toLowerCase}%"),
pColl.is(coll)
) ++ concerning.map(pConc.is(_)).toSeq ++ ck.map(cKind.is(_)).toSeq
selectDistinct(PC.all.map(_.prefix("p")), from, and(q))
.query[RPerson]
.stream
}
def addOrg[F[_]]( def addOrg[F[_]](
org: ROrganization, org: ROrganization,
contacts: Seq[RContact], contacts: Seq[RContact],

View File

@ -6,6 +6,7 @@ import doobie.implicits._
import docspell.common._ import docspell.common._
import docspell.store.impl._ import docspell.store.impl._
import docspell.store.impl.Implicits._ import docspell.store.impl.Implicits._
import cats.data.NonEmptyList
/** The archive file of some attachment. The `id` is shared with the /** The archive file of some attachment. The `id` is shared with the
* attachment, to create a 0..1-1 relationship. * attachment, to create a 0..1-1 relationship.
@ -72,6 +73,26 @@ object RAttachmentArchive {
selectSimple(all.map(_.prefix("a")), from, where).query[RAttachmentArchive].option selectSimple(all.map(_.prefix("a")), from, where).query[RAttachmentArchive].option
} }
def findByMessageIdAndCollective(
messageIds: NonEmptyList[String],
collective: Ident
): ConnectionIO[Vector[RAttachmentArchive]] = {
val bId = RAttachment.Columns.id.prefix("b")
val bItem = RAttachment.Columns.itemId.prefix("b")
val aMsgId = Columns.messageId.prefix("a")
val aId = Columns.id.prefix("a")
val iId = RItem.Columns.id.prefix("i")
val iColl = RItem.Columns.cid.prefix("i")
val from = table ++ fr"a INNER JOIN" ++
RAttachment.table ++ fr"b ON" ++ aId.is(bId) ++
fr"INNER JOIN" ++ RItem.table ++ fr"i ON" ++ bItem.is(iId)
val where = and(aMsgId.isIn(messageIds), iColl.is(collective))
selectSimple(all.map(_.prefix("a")), from, where).query[RAttachmentArchive].to[Vector]
}
def findByItemWithMeta( def findByItemWithMeta(
id: Ident id: Ident
): ConnectionIO[Vector[(RAttachmentArchive, FileMeta)]] = { ): ConnectionIO[Vector[(RAttachmentArchive, FileMeta)]] = {

View File

@ -0,0 +1,201 @@
package docspell.store.records
import doobie._
import doobie.implicits._
import cats.effect._
import cats.implicits._
import cats.data.OptionT
import docspell.common._
import docspell.store.impl.Column
import docspell.store.impl.Implicits._
import emil.{MailConfig, SSLType}
case class RUserImap(
id: Ident,
uid: Ident,
name: Ident,
imapHost: String,
imapPort: Option[Int],
imapUser: Option[String],
imapPassword: Option[Password],
imapSsl: SSLType,
imapCertCheck: Boolean,
created: Timestamp
) {
def toMailConfig: MailConfig = {
val port = imapPort.map(p => s":$p").getOrElse("")
MailConfig(
s"imap://$imapHost$port",
imapUser.getOrElse(""),
imapPassword.map(_.pass).getOrElse(""),
imapSsl,
!imapCertCheck
)
}
}
object RUserImap {
def apply[F[_]: Sync](
uid: Ident,
name: Ident,
imapHost: String,
imapPort: Option[Int],
imapUser: Option[String],
imapPassword: Option[Password],
imapSsl: SSLType,
imapCertCheck: Boolean
): F[RUserImap] =
for {
now <- Timestamp.current[F]
id <- Ident.randomId[F]
} yield RUserImap(
id,
uid,
name,
imapHost,
imapPort,
imapUser,
imapPassword,
imapSsl,
imapCertCheck,
now
)
def fromAccount(
accId: AccountId,
name: Ident,
imapHost: String,
imapPort: Option[Int],
imapUser: Option[String],
imapPassword: Option[Password],
imapSsl: SSLType,
imapCertCheck: Boolean
): OptionT[ConnectionIO, RUserImap] =
for {
now <- OptionT.liftF(Timestamp.current[ConnectionIO])
id <- OptionT.liftF(Ident.randomId[ConnectionIO])
user <- OptionT(RUser.findByAccount(accId))
} yield RUserImap(
id,
user.uid,
name,
imapHost,
imapPort,
imapUser,
imapPassword,
imapSsl,
imapCertCheck,
now
)
val table = fr"userimap"
object Columns {
val id = Column("id")
val uid = Column("uid")
val name = Column("name")
val imapHost = Column("imap_host")
val imapPort = Column("imap_port")
val imapUser = Column("imap_user")
val imapPass = Column("imap_password")
val imapSsl = Column("imap_ssl")
val imapCertCheck = Column("imap_certcheck")
val created = Column("created")
val all = List(
id,
uid,
name,
imapHost,
imapPort,
imapUser,
imapPass,
imapSsl,
imapCertCheck,
created
)
}
import Columns._
def insert(v: RUserImap): ConnectionIO[Int] =
insertRow(
table,
all,
sql"${v.id},${v.uid},${v.name},${v.imapHost},${v.imapPort},${v.imapUser},${v.imapPassword},${v.imapSsl},${v.imapCertCheck},${v.created}"
).update.run
def update(eId: Ident, v: RUserImap): ConnectionIO[Int] =
updateRow(
table,
id.is(eId),
commas(
name.setTo(v.name),
imapHost.setTo(v.imapHost),
imapPort.setTo(v.imapPort),
imapUser.setTo(v.imapUser),
imapPass.setTo(v.imapPassword),
imapSsl.setTo(v.imapSsl),
imapCertCheck.setTo(v.imapCertCheck)
)
).update.run
def findByUser(userId: Ident): ConnectionIO[Vector[RUserImap]] =
selectSimple(all, table, uid.is(userId)).query[RUserImap].to[Vector]
private def findByAccount0(
accId: AccountId,
nameQ: Option[String],
exact: Boolean
): Query0[RUserImap] = {
val mUid = uid.prefix("m")
val mName = name.prefix("m")
val uId = RUser.Columns.uid.prefix("u")
val uColl = RUser.Columns.cid.prefix("u")
val uLogin = RUser.Columns.login.prefix("u")
val from = table ++ fr"m INNER JOIN" ++ RUser.table ++ fr"u ON" ++ mUid.is(uId)
val cond = Seq(uColl.is(accId.collective), uLogin.is(accId.user)) ++ (nameQ match {
case Some(str) if exact => Seq(mName.is(str))
case Some(str) if !exact => Seq(mName.lowerLike(s"%${str.toLowerCase}%"))
case None => Seq.empty
})
(selectSimple(all.map(_.prefix("m")), from, and(cond)) ++ orderBy(mName.f))
.query[RUserImap]
}
def findByAccount(
accId: AccountId,
nameQ: Option[String]
): ConnectionIO[Vector[RUserImap]] =
findByAccount0(accId, nameQ, false).to[Vector]
def getByName(accId: AccountId, name: Ident): ConnectionIO[Option[RUserImap]] =
findByAccount0(accId, Some(name.id), true).option
def delete(accId: AccountId, connName: Ident): ConnectionIO[Int] = {
val uId = RUser.Columns.uid
val uColl = RUser.Columns.cid
val uLogin = RUser.Columns.login
val cond = Seq(uColl.is(accId.collective), uLogin.is(accId.user))
deleteFrom(
table,
fr"uid in (" ++ selectSimple(Seq(uId), RUser.table, and(cond)) ++ fr") AND" ++ name
.is(
connName
)
).update.run
}
def exists(accId: AccountId, name: Ident): ConnectionIO[Boolean] =
getByName(accId, name).map(_.isDefined)
def exists(userId: Ident, connName: Ident): ConnectionIO[Boolean] =
selectCount(id, table, and(uid.is(userId), name.is(connName)))
.query[Int]
.unique
.map(_ > 0)
}

View File

@ -2,9 +2,11 @@ module Api exposing
( cancelJob ( cancelJob
, changePassword , changePassword
, checkCalEvent , checkCalEvent
, createImapSettings
, createMailSettings , createMailSettings
, deleteAttachment , deleteAttachment
, deleteEquip , deleteEquip
, deleteImapSettings
, deleteItem , deleteItem
, deleteMailSettings , deleteMailSettings
, deleteOrg , deleteOrg
@ -17,6 +19,7 @@ module Api exposing
, getCollectiveSettings , getCollectiveSettings
, getContacts , getContacts
, getEquipments , getEquipments
, getImapSettings
, getInsights , getInsights
, getItemProposals , getItemProposals
, getJobQueueState , getJobQueueState
@ -27,6 +30,7 @@ module Api exposing
, getOrganizations , getOrganizations
, getPersons , getPersons
, getPersonsLight , getPersonsLight
, getScanMailbox
, getSentMails , getSentMails
, getSources , getSources
, getTags , getTags
@ -61,7 +65,9 @@ module Api exposing
, setTags , setTags
, setUnconfirmed , setUnconfirmed
, startOnceNotifyDueItems , startOnceNotifyDueItems
, startOnceScanMailbox
, submitNotifyDueItems , submitNotifyDueItems
, submitScanMailbox
, upload , upload
, uploadSingle , uploadSingle
, versionInfo , versionInfo
@ -81,6 +87,8 @@ import Api.Model.EmailSettingsList exposing (EmailSettingsList)
import Api.Model.Equipment exposing (Equipment) import Api.Model.Equipment exposing (Equipment)
import Api.Model.EquipmentList exposing (EquipmentList) import Api.Model.EquipmentList exposing (EquipmentList)
import Api.Model.GenInvite exposing (GenInvite) import Api.Model.GenInvite exposing (GenInvite)
import Api.Model.ImapSettings exposing (ImapSettings)
import Api.Model.ImapSettingsList exposing (ImapSettingsList)
import Api.Model.InviteResult exposing (InviteResult) import Api.Model.InviteResult exposing (InviteResult)
import Api.Model.ItemDetail exposing (ItemDetail) import Api.Model.ItemDetail exposing (ItemDetail)
import Api.Model.ItemInsights exposing (ItemInsights) import Api.Model.ItemInsights exposing (ItemInsights)
@ -100,6 +108,7 @@ import Api.Model.Person exposing (Person)
import Api.Model.PersonList exposing (PersonList) import Api.Model.PersonList exposing (PersonList)
import Api.Model.ReferenceList exposing (ReferenceList) import Api.Model.ReferenceList exposing (ReferenceList)
import Api.Model.Registration exposing (Registration) import Api.Model.Registration exposing (Registration)
import Api.Model.ScanMailboxSettings exposing (ScanMailboxSettings)
import Api.Model.SentMails exposing (SentMails) import Api.Model.SentMails exposing (SentMails)
import Api.Model.SimpleMail exposing (SimpleMail) import Api.Model.SimpleMail exposing (SimpleMail)
import Api.Model.Source exposing (Source) import Api.Model.Source exposing (Source)
@ -122,6 +131,50 @@ import Util.Http as Http2
--- Scan Mailboxes
startOnceScanMailbox :
Flags
-> ScanMailboxSettings
-> (Result Http.Error BasicResult -> msg)
-> Cmd msg
startOnceScanMailbox flags settings receive =
Http2.authPost
{ url = flags.config.baseUrl ++ "/api/v1/sec/usertask/scanmailbox/startonce"
, account = getAccount flags
, body = Http.jsonBody (Api.Model.ScanMailboxSettings.encode settings)
, expect = Http.expectJson receive Api.Model.BasicResult.decoder
}
submitScanMailbox :
Flags
-> ScanMailboxSettings
-> (Result Http.Error BasicResult -> msg)
-> Cmd msg
submitScanMailbox flags settings receive =
Http2.authPost
{ url = flags.config.baseUrl ++ "/api/v1/sec/usertask/scanmailbox"
, account = getAccount flags
, body = Http.jsonBody (Api.Model.ScanMailboxSettings.encode settings)
, expect = Http.expectJson receive Api.Model.BasicResult.decoder
}
getScanMailbox :
Flags
-> (Result Http.Error ScanMailboxSettings -> msg)
-> Cmd msg
getScanMailbox flags receive =
Http2.authGet
{ url = flags.config.baseUrl ++ "/api/v1/sec/usertask/scanmailbox"
, account = getAccount flags
, expect = Http.expectJson receive Api.Model.ScanMailboxSettings.decoder
}
--- NotifyDueItems --- NotifyDueItems
@ -259,7 +312,16 @@ sendMail flags opts receive =
deleteMailSettings : Flags -> String -> (Result Http.Error BasicResult -> msg) -> Cmd msg deleteMailSettings : Flags -> String -> (Result Http.Error BasicResult -> msg) -> Cmd msg
deleteMailSettings flags name receive = deleteMailSettings flags name receive =
Http2.authDelete Http2.authDelete
{ url = flags.config.baseUrl ++ "/api/v1/sec/email/settings/" ++ name { url = flags.config.baseUrl ++ "/api/v1/sec/email/settings/smtp/" ++ name
, account = getAccount flags
, expect = Http.expectJson receive Api.Model.BasicResult.decoder
}
deleteImapSettings : Flags -> String -> (Result Http.Error BasicResult -> msg) -> Cmd msg
deleteImapSettings flags name receive =
Http2.authDelete
{ url = flags.config.baseUrl ++ "/api/v1/sec/email/settings/imap/" ++ name
, account = getAccount flags , account = getAccount flags
, expect = Http.expectJson receive Api.Model.BasicResult.decoder , expect = Http.expectJson receive Api.Model.BasicResult.decoder
} }
@ -268,12 +330,21 @@ deleteMailSettings flags name receive =
getMailSettings : Flags -> String -> (Result Http.Error EmailSettingsList -> msg) -> Cmd msg getMailSettings : Flags -> String -> (Result Http.Error EmailSettingsList -> msg) -> Cmd msg
getMailSettings flags query receive = getMailSettings flags query receive =
Http2.authGet Http2.authGet
{ url = flags.config.baseUrl ++ "/api/v1/sec/email/settings?q=" ++ Url.percentEncode query { url = flags.config.baseUrl ++ "/api/v1/sec/email/settings/smtp?q=" ++ Url.percentEncode query
, account = getAccount flags , account = getAccount flags
, expect = Http.expectJson receive Api.Model.EmailSettingsList.decoder , expect = Http.expectJson receive Api.Model.EmailSettingsList.decoder
} }
getImapSettings : Flags -> String -> (Result Http.Error ImapSettingsList -> msg) -> Cmd msg
getImapSettings flags query receive =
Http2.authGet
{ url = flags.config.baseUrl ++ "/api/v1/sec/email/settings/imap?q=" ++ Url.percentEncode query
, account = getAccount flags
, expect = Http.expectJson receive Api.Model.ImapSettingsList.decoder
}
createMailSettings : createMailSettings :
Flags Flags
-> Maybe String -> Maybe String
@ -284,7 +355,7 @@ createMailSettings flags mname ems receive =
case mname of case mname of
Just en -> Just en ->
Http2.authPut Http2.authPut
{ url = flags.config.baseUrl ++ "/api/v1/sec/email/settings/" ++ en { url = flags.config.baseUrl ++ "/api/v1/sec/email/settings/smtp/" ++ en
, account = getAccount flags , account = getAccount flags
, body = Http.jsonBody (Api.Model.EmailSettings.encode ems) , body = Http.jsonBody (Api.Model.EmailSettings.encode ems)
, expect = Http.expectJson receive Api.Model.BasicResult.decoder , expect = Http.expectJson receive Api.Model.BasicResult.decoder
@ -292,13 +363,38 @@ createMailSettings flags mname ems receive =
Nothing -> Nothing ->
Http2.authPost Http2.authPost
{ url = flags.config.baseUrl ++ "/api/v1/sec/email/settings" { url = flags.config.baseUrl ++ "/api/v1/sec/email/settings/smtp"
, account = getAccount flags , account = getAccount flags
, body = Http.jsonBody (Api.Model.EmailSettings.encode ems) , body = Http.jsonBody (Api.Model.EmailSettings.encode ems)
, expect = Http.expectJson receive Api.Model.BasicResult.decoder , expect = Http.expectJson receive Api.Model.BasicResult.decoder
} }
createImapSettings :
Flags
-> Maybe String
-> ImapSettings
-> (Result Http.Error BasicResult -> msg)
-> Cmd msg
createImapSettings flags mname ems receive =
case mname of
Just en ->
Http2.authPut
{ url = flags.config.baseUrl ++ "/api/v1/sec/email/settings/imap/" ++ en
, account = getAccount flags
, body = Http.jsonBody (Api.Model.ImapSettings.encode ems)
, expect = Http.expectJson receive Api.Model.BasicResult.decoder
}
Nothing ->
Http2.authPost
{ url = flags.config.baseUrl ++ "/api/v1/sec/email/settings/imap"
, account = getAccount flags
, body = Http.jsonBody (Api.Model.ImapSettings.encode ems)
, expect = Http.expectJson receive Api.Model.BasicResult.decoder
}
--- Upload --- Upload

View File

@ -0,0 +1,226 @@
module Comp.ImapSettingsForm exposing
( Model
, Msg
, emptyModel
, getSettings
, init
, isValid
, update
, view
)
import Api.Model.ImapSettings exposing (ImapSettings)
import Comp.Dropdown
import Comp.IntField
import Comp.PasswordInput
import Data.SSLType exposing (SSLType)
import Html exposing (..)
import Html.Attributes exposing (..)
import Html.Events exposing (onCheck, onInput)
import Util.Maybe
type alias Model =
{ settings : ImapSettings
, name : String
, host : String
, portField : Comp.IntField.Model
, portNum : Maybe Int
, user : Maybe String
, passField : Comp.PasswordInput.Model
, password : Maybe String
, sslType : Comp.Dropdown.Model SSLType
, ignoreCertificates : Bool
}
emptyModel : Model
emptyModel =
{ settings = Api.Model.ImapSettings.empty
, name = ""
, host = ""
, portField = Comp.IntField.init (Just 0) Nothing True "IMAP Port"
, portNum = Nothing
, user = Nothing
, passField = Comp.PasswordInput.init
, password = Nothing
, sslType =
Comp.Dropdown.makeSingleList
{ makeOption = \s -> { value = Data.SSLType.toString s, text = Data.SSLType.label s }
, placeholder = ""
, options = Data.SSLType.all
, selected = Just Data.SSLType.None
}
, ignoreCertificates = False
}
init : ImapSettings -> Model
init ems =
{ settings = ems
, name = ems.name
, host = ems.imapHost
, portField = Comp.IntField.init (Just 0) Nothing True "IMAP Port"
, portNum = ems.imapPort
, user = ems.imapUser
, passField = Comp.PasswordInput.init
, password = ems.imapPassword
, sslType =
Comp.Dropdown.makeSingleList
{ makeOption = \s -> { value = Data.SSLType.toString s, text = Data.SSLType.label s }
, placeholder = ""
, options = Data.SSLType.all
, selected =
Data.SSLType.fromString ems.sslType
|> Maybe.withDefault Data.SSLType.None
|> Just
}
, ignoreCertificates = ems.ignoreCertificates
}
getSettings : Model -> ( Maybe String, ImapSettings )
getSettings model =
( Util.Maybe.fromString model.settings.name
, { name = model.name
, imapHost = model.host
, imapUser = model.user
, imapPort = model.portNum
, imapPassword = model.password
, sslType =
Comp.Dropdown.getSelected model.sslType
|> List.head
|> Maybe.withDefault Data.SSLType.None
|> Data.SSLType.toString
, ignoreCertificates = model.ignoreCertificates
}
)
type Msg
= SetName String
| SetHost String
| PortMsg Comp.IntField.Msg
| SetUser String
| PassMsg Comp.PasswordInput.Msg
| SSLTypeMsg (Comp.Dropdown.Msg SSLType)
| ToggleCheckCert
isValid : Model -> Bool
isValid model =
model.host /= "" && model.name /= ""
update : Msg -> Model -> ( Model, Cmd Msg )
update msg model =
case msg of
SetName str ->
( { model | name = str }, Cmd.none )
SetHost str ->
( { model | host = str }, Cmd.none )
PortMsg m ->
let
( pm, val ) =
Comp.IntField.update m model.portField
in
( { model | portField = pm, portNum = val }, Cmd.none )
SetUser str ->
( { model | user = Util.Maybe.fromString str }, Cmd.none )
PassMsg m ->
let
( pm, val ) =
Comp.PasswordInput.update m model.passField
in
( { model | passField = pm, password = val }, Cmd.none )
SSLTypeMsg m ->
let
( sm, sc ) =
Comp.Dropdown.update m model.sslType
in
( { model | sslType = sm }, Cmd.map SSLTypeMsg sc )
ToggleCheckCert ->
( { model | ignoreCertificates = not model.ignoreCertificates }, Cmd.none )
view : Model -> Html Msg
view model =
div
[ classList
[ ( "ui form", True )
, ( "error", not (isValid model) )
, ( "success", isValid model )
]
]
[ div [ class "required field" ]
[ label [] [ text "Name" ]
, input
[ type_ "text"
, value model.name
, onInput SetName
, placeholder "Connection name, e.g. 'gmail.com'"
]
[]
, div [ class "ui info message" ]
[ text "The connection name must not contain whitespace or special characters."
]
]
, div [ class "fields" ]
[ div [ class "thirteen wide required field" ]
[ label [] [ text "IMAP Host" ]
, input
[ type_ "text"
, placeholder "IMAP host name, e.g. 'mail.gmail.com'"
, value model.host
, onInput SetHost
]
[]
]
, Html.map PortMsg
(Comp.IntField.view model.portNum
"three wide field"
model.portField
)
]
, div [ class "two fields" ]
[ div [ class "field" ]
[ label [] [ text "IMAP User" ]
, input
[ type_ "text"
, placeholder "IMAP Username, e.g. 'your.name@gmail.com'"
, Maybe.withDefault "" model.user |> value
, onInput SetUser
]
[]
]
, div [ class "field" ]
[ label [] [ text "IMAP Password" ]
, Html.map PassMsg (Comp.PasswordInput.view model.password model.passField)
]
]
, div [ class "two fields" ]
[ div [ class "inline field" ]
[ div [ class "ui checkbox" ]
[ input
[ type_ "checkbox"
, checked model.ignoreCertificates
, onCheck (\_ -> ToggleCheckCert)
]
[]
, label [] [ text "Ignore certificate check" ]
]
]
]
, div [ class "two fields" ]
[ div [ class "field" ]
[ label [] [ text "SSL" ]
, Html.map SSLTypeMsg (Comp.Dropdown.view model.sslType)
]
]
]

View File

@ -0,0 +1,288 @@
module Comp.ImapSettingsManage exposing
( Model
, Msg
, emptyModel
, init
, update
, view
)
import Api
import Api.Model.BasicResult exposing (BasicResult)
import Api.Model.ImapSettings
import Api.Model.ImapSettingsList exposing (ImapSettingsList)
import Comp.ImapSettingsForm
import Comp.ImapSettingsTable
import Comp.YesNoDimmer
import Data.Flags exposing (Flags)
import Html exposing (..)
import Html.Attributes exposing (..)
import Html.Events exposing (onClick, onInput)
import Http
import Util.Http
type alias Model =
{ tableModel : Comp.ImapSettingsTable.Model
, formModel : Comp.ImapSettingsForm.Model
, viewMode : ViewMode
, formError : Maybe String
, loading : Bool
, query : String
, deleteConfirm : Comp.YesNoDimmer.Model
}
emptyModel : Model
emptyModel =
{ tableModel = Comp.ImapSettingsTable.emptyModel
, formModel = Comp.ImapSettingsForm.emptyModel
, viewMode = Table
, formError = Nothing
, loading = False
, query = ""
, deleteConfirm = Comp.YesNoDimmer.emptyModel
}
init : Flags -> ( Model, Cmd Msg )
init flags =
( emptyModel, Api.getImapSettings flags "" MailSettingsResp )
type ViewMode
= Table
| Form
type Msg
= TableMsg Comp.ImapSettingsTable.Msg
| FormMsg Comp.ImapSettingsForm.Msg
| SetQuery String
| InitNew
| YesNoMsg Comp.YesNoDimmer.Msg
| RequestDelete
| SetViewMode ViewMode
| Submit
| SubmitResp (Result Http.Error BasicResult)
| LoadSettings
| MailSettingsResp (Result Http.Error ImapSettingsList)
update : Flags -> Msg -> Model -> ( Model, Cmd Msg )
update flags msg model =
case msg of
InitNew ->
let
ems =
Api.Model.ImapSettings.empty
nm =
{ model
| viewMode = Form
, formError = Nothing
, formModel = Comp.ImapSettingsForm.init ems
}
in
( nm, Cmd.none )
TableMsg m ->
let
( tm, tc ) =
Comp.ImapSettingsTable.update m model.tableModel
m2 =
{ model
| tableModel = tm
, viewMode = Maybe.map (\_ -> Form) tm.selected |> Maybe.withDefault Table
, formError =
if tm.selected /= Nothing then
Nothing
else
model.formError
, formModel =
case tm.selected of
Just ems ->
Comp.ImapSettingsForm.init ems
Nothing ->
model.formModel
}
in
( m2, Cmd.map TableMsg tc )
FormMsg m ->
let
( fm, fc ) =
Comp.ImapSettingsForm.update m model.formModel
in
( { model | formModel = fm }, Cmd.map FormMsg fc )
SetQuery str ->
let
m =
{ model | query = str }
in
( m, Api.getImapSettings flags str MailSettingsResp )
YesNoMsg m ->
let
( dm, flag ) =
Comp.YesNoDimmer.update m model.deleteConfirm
( mid, _ ) =
Comp.ImapSettingsForm.getSettings model.formModel
cmd =
case ( flag, mid ) of
( True, Just name ) ->
Api.deleteImapSettings flags name SubmitResp
_ ->
Cmd.none
in
( { model | deleteConfirm = dm }, cmd )
RequestDelete ->
update flags (YesNoMsg Comp.YesNoDimmer.activate) model
SetViewMode m ->
( { model | viewMode = m }, Cmd.none )
Submit ->
let
( mid, ems ) =
Comp.ImapSettingsForm.getSettings model.formModel
valid =
Comp.ImapSettingsForm.isValid model.formModel
in
if valid then
( { model | loading = True }, Api.createImapSettings flags mid ems SubmitResp )
else
( { model | formError = Just "Please fill required fields." }, Cmd.none )
LoadSettings ->
( { model | loading = True }, Api.getImapSettings flags model.query MailSettingsResp )
SubmitResp (Ok res) ->
if res.success then
let
( m2, c2 ) =
update flags (SetViewMode Table) model
( m3, c3 ) =
update flags LoadSettings m2
in
( { m3 | loading = False }, Cmd.batch [ c2, c3 ] )
else
( { model | formError = Just res.message, loading = False }, Cmd.none )
SubmitResp (Err err) ->
( { model | formError = Just (Util.Http.errorToString err), loading = False }, Cmd.none )
MailSettingsResp (Ok ems) ->
let
m2 =
{ model
| viewMode = Table
, loading = False
, tableModel = Comp.ImapSettingsTable.init ems.items
}
in
( m2, Cmd.none )
MailSettingsResp (Err _) ->
( { model | loading = False }, Cmd.none )
view : Model -> Html Msg
view model =
case model.viewMode of
Table ->
viewTable model
Form ->
viewForm model
viewTable : Model -> Html Msg
viewTable model =
div []
[ div [ class "ui secondary menu" ]
[ div [ class "horizontally fitted item" ]
[ div [ class "ui icon input" ]
[ input
[ type_ "text"
, onInput SetQuery
, value model.query
, placeholder "Search"
]
[]
, i [ class "ui search icon" ]
[]
]
]
, div [ class "right menu" ]
[ div [ class "item" ]
[ a
[ class "ui primary button"
, href "#"
, onClick InitNew
]
[ i [ class "plus icon" ] []
, text "New Settings"
]
]
]
]
, Html.map TableMsg (Comp.ImapSettingsTable.view model.tableModel)
]
viewForm : Model -> Html Msg
viewForm model =
div [ class "ui segment" ]
[ Html.map YesNoMsg (Comp.YesNoDimmer.view model.deleteConfirm)
, Html.map FormMsg (Comp.ImapSettingsForm.view model.formModel)
, div
[ classList
[ ( "ui error message", True )
, ( "invisible", model.formError == Nothing )
]
]
[ Maybe.withDefault "" model.formError |> text
]
, div [ class "ui divider" ] []
, button
[ class "ui primary button"
, onClick Submit
, href "#"
]
[ text "Submit"
]
, a
[ class "ui secondary button"
, onClick (SetViewMode Table)
, href ""
]
[ text "Cancel"
]
, if model.formModel.settings.name /= "" then
a [ class "ui right floated red button", href "", onClick RequestDelete ]
[ text "Delete" ]
else
span [] []
, div
[ classList
[ ( "ui dimmer", True )
, ( "active", model.loading )
]
]
[ div [ class "ui loader" ] []
]
]

View File

@ -0,0 +1,74 @@
module Comp.ImapSettingsTable exposing
( Model
, Msg
, emptyModel
, init
, update
, view
)
import Api.Model.ImapSettings exposing (ImapSettings)
import Html exposing (..)
import Html.Attributes exposing (..)
import Html.Events exposing (onClick)
type alias Model =
{ emailSettings : List ImapSettings
, selected : Maybe ImapSettings
}
emptyModel : Model
emptyModel =
init []
init : List ImapSettings -> Model
init ems =
{ emailSettings = ems
, selected = Nothing
}
type Msg
= Select ImapSettings
update : Msg -> Model -> ( Model, Cmd Msg )
update msg model =
case msg of
Select ems ->
( { model | selected = Just ems }, Cmd.none )
view : Model -> Html Msg
view model =
table [ class "ui selectable pointer table" ]
[ thead []
[ th [ class "collapsible" ] [ text "Name" ]
, th [] [ text "Host/Port" ]
]
, tbody []
(List.map (renderLine model) model.emailSettings)
]
renderLine : Model -> ImapSettings -> Html Msg
renderLine model ems =
let
hostport =
case ems.imapPort of
Just p ->
ems.imapHost ++ ":" ++ String.fromInt p
Nothing ->
ems.imapHost
in
tr
[ classList [ ( "active", model.selected == Just ems ) ]
, onClick (Select ems)
]
[ td [ class "collapsible" ] [ text ems.name ]
, td [] [ text hostport ]
]

View File

@ -0,0 +1,562 @@
module Comp.ScanMailboxForm exposing
( Model
, Msg
, init
, update
, view
)
import Api
import Api.Model.BasicResult exposing (BasicResult)
import Api.Model.ImapSettingsList exposing (ImapSettingsList)
import Api.Model.ScanMailboxSettings exposing (ScanMailboxSettings)
import Api.Model.Tag exposing (Tag)
import Api.Model.TagList exposing (TagList)
import Comp.CalEventInput
import Comp.Dropdown
import Comp.IntField
import Comp.StringListInput
import Data.CalEvent exposing (CalEvent)
import Data.Direction exposing (Direction(..))
import Data.Flags exposing (Flags)
import Data.Validated exposing (Validated(..))
import Html exposing (..)
import Html.Attributes exposing (..)
import Html.Events exposing (onCheck, onClick, onInput)
import Http
import Util.Http
import Util.List
import Util.Maybe
import Util.Update
type alias Model =
{ settings : ScanMailboxSettings
, connectionModel : Comp.Dropdown.Model String
, enabled : Bool
, deleteMail : Bool
, receivedHours : Maybe Int
, receivedHoursModel : Comp.IntField.Model
, targetFolder : Maybe String
, foldersModel : Comp.StringListInput.Model
, folders : List String
, direction : Maybe Direction
, schedule : Validated CalEvent
, scheduleModel : Comp.CalEventInput.Model
, formMsg : Maybe BasicResult
, loading : Int
}
type Msg
= Submit
| ConnMsg (Comp.Dropdown.Msg String)
| ConnResp (Result Http.Error ImapSettingsList)
| ToggleEnabled
| ToggleDeleteMail
| CalEventMsg Comp.CalEventInput.Msg
| SetScanMailboxSettings (Result Http.Error ScanMailboxSettings)
| SubmitResp (Result Http.Error BasicResult)
| StartOnce
| ReceivedHoursMsg Comp.IntField.Msg
| SetTargetFolder String
| FoldersMsg Comp.StringListInput.Msg
| DirectionMsg (Maybe Direction)
initCmd : Flags -> Cmd Msg
initCmd flags =
Cmd.batch
[ Api.getImapSettings flags "" ConnResp
, Api.getScanMailbox flags SetScanMailboxSettings
]
init : Flags -> ( Model, Cmd Msg )
init flags =
let
initialSchedule =
Data.Validated.Unknown Data.CalEvent.everyMonth
( sm, sc ) =
Comp.CalEventInput.init flags Data.CalEvent.everyMonth
in
( { settings = Api.Model.ScanMailboxSettings.empty
, connectionModel =
Comp.Dropdown.makeSingle
{ makeOption = \a -> { value = a, text = a }
, placeholder = "Select connection..."
}
, enabled = False
, deleteMail = False
, receivedHours = Nothing
, receivedHoursModel = Comp.IntField.init (Just 1) Nothing True "Received Since Hours"
, foldersModel = Comp.StringListInput.init
, folders = []
, targetFolder = Nothing
, direction = Nothing
, schedule = initialSchedule
, scheduleModel = sm
, formMsg = Nothing
, loading = 2
}
, Cmd.batch
[ initCmd flags
, Cmd.map CalEventMsg sc
]
)
--- Update
makeSettings : Model -> Validated ScanMailboxSettings
makeSettings model =
let
prev =
model.settings
conn =
Comp.Dropdown.getSelected model.connectionModel
|> List.head
|> Maybe.map Valid
|> Maybe.withDefault (Invalid [ "Connection missing" ] "")
infolders =
if model.folders == [] then
Invalid [ "No folders given" ] []
else
Valid model.folders
make smtp timer folders =
{ prev
| imapConnection = smtp
, enabled = model.enabled
, receivedSinceHours = model.receivedHours
, deleteMail = model.deleteMail
, targetFolder = model.targetFolder
, folders = folders
, direction = Maybe.map Data.Direction.toString model.direction
, schedule = Data.CalEvent.makeEvent timer
}
in
Data.Validated.map3 make
conn
model.schedule
infolders
withValidSettings : (ScanMailboxSettings -> Cmd Msg) -> Model -> ( Model, Cmd Msg )
withValidSettings mkcmd model =
case makeSettings model of
Valid set ->
( { model | formMsg = Nothing }
, mkcmd set
)
Invalid errs _ ->
let
errMsg =
String.join ", " errs
in
( { model | formMsg = Just (BasicResult False errMsg) }, Cmd.none )
Unknown _ ->
( { model | formMsg = Just (BasicResult False "An unknown error occured") }
, Cmd.none
)
update : Flags -> Msg -> Model -> ( Model, Cmd Msg )
update flags msg model =
case msg of
CalEventMsg lmsg ->
let
( cm, cc, cs ) =
Comp.CalEventInput.update flags
(Data.Validated.value model.schedule)
lmsg
model.scheduleModel
in
( { model
| schedule = cs
, scheduleModel = cm
, formMsg = Nothing
}
, Cmd.map CalEventMsg cc
)
ConnMsg m ->
let
( cm, cc ) =
Comp.Dropdown.update m model.connectionModel
in
( { model
| connectionModel = cm
, formMsg = Nothing
}
, Cmd.map ConnMsg cc
)
ConnResp (Ok list) ->
let
names =
List.map .name list.items
cm =
Comp.Dropdown.makeSingleList
{ makeOption = \a -> { value = a, text = a }
, placeholder = "Select Connection..."
, options = names
, selected = List.head names
}
in
( { model
| connectionModel = cm
, loading = model.loading - 1
, formMsg =
if names == [] then
Just
(BasicResult False
"No E-Mail connections configured. Goto E-Mail Settings to add one."
)
else
Nothing
}
, Cmd.none
)
ConnResp (Err err) ->
( { model
| formMsg = Just (BasicResult False (Util.Http.errorToString err))
, loading = model.loading - 1
}
, Cmd.none
)
ToggleEnabled ->
( { model
| enabled = not model.enabled
, formMsg = Nothing
}
, Cmd.none
)
ToggleDeleteMail ->
( { model
| deleteMail = not model.deleteMail
, formMsg = Nothing
}
, Cmd.none
)
ReceivedHoursMsg m ->
let
( pm, val ) =
Comp.IntField.update m model.receivedHoursModel
in
( { model
| receivedHoursModel = pm
, receivedHours = val
, formMsg = Nothing
}
, Cmd.none
)
SetTargetFolder str ->
( { model | targetFolder = Util.Maybe.fromString str }
, Cmd.none
)
FoldersMsg lm ->
let
( fm, itemAction ) =
Comp.StringListInput.update lm model.foldersModel
newList =
case itemAction of
Comp.StringListInput.AddAction s ->
Util.List.distinct (s :: model.folders)
Comp.StringListInput.RemoveAction s ->
List.filter (\e -> e /= s) model.folders
Comp.StringListInput.NoAction ->
model.folders
in
( { model
| foldersModel = fm
, folders = newList
}
, Cmd.none
)
DirectionMsg md ->
( { model | direction = md }
, Cmd.none
)
SetScanMailboxSettings (Ok s) ->
let
imap =
Util.Maybe.fromString s.imapConnection
|> Maybe.map List.singleton
|> Maybe.withDefault []
( nm, nc ) =
Util.Update.andThen1
[ update flags (ConnMsg (Comp.Dropdown.SetSelection imap))
]
model
newSchedule =
Data.CalEvent.fromEvent s.schedule
|> Maybe.withDefault Data.CalEvent.everyMonth
( sm, sc ) =
Comp.CalEventInput.init flags newSchedule
in
( { nm
| settings = s
, enabled = s.enabled
, deleteMail = s.deleteMail
, receivedHours = s.receivedSinceHours
, targetFolder = s.targetFolder
, folders = s.folders
, schedule = Data.Validated.Unknown newSchedule
, direction = Maybe.andThen Data.Direction.fromString s.direction
, scheduleModel = sm
, formMsg = Nothing
, loading = model.loading - 1
}
, Cmd.batch
[ nc
, Cmd.map CalEventMsg sc
]
)
SetScanMailboxSettings (Err err) ->
( { model
| formMsg = Just (BasicResult False (Util.Http.errorToString err))
, loading = model.loading - 1
}
, Cmd.none
)
Submit ->
withValidSettings
(\set -> Api.submitScanMailbox flags set SubmitResp)
model
StartOnce ->
withValidSettings
(\set -> Api.startOnceScanMailbox flags set SubmitResp)
model
SubmitResp (Ok res) ->
( { model | formMsg = Just res }
, Cmd.none
)
SubmitResp (Err err) ->
( { model
| formMsg = Just (BasicResult False (Util.Http.errorToString err))
}
, Cmd.none
)
--- View
isFormError : Model -> Bool
isFormError model =
Maybe.map .success model.formMsg
|> Maybe.map not
|> Maybe.withDefault False
isFormSuccess : Model -> Bool
isFormSuccess model =
Maybe.map .success model.formMsg
|> Maybe.withDefault False
view : String -> Model -> Html Msg
view extraClasses model =
div
[ classList
[ ( "ui form", True )
, ( extraClasses, True )
, ( "error", isFormError model )
, ( "success", isFormSuccess model )
]
]
[ div
[ classList
[ ( "ui dimmer", True )
, ( "active", model.loading > 0 )
]
]
[ div [ class "ui text loader" ]
[ text "Loading..."
]
]
, div [ class "inline field" ]
[ div [ class "ui checkbox" ]
[ input
[ type_ "checkbox"
, onCheck (\_ -> ToggleEnabled)
, checked model.enabled
]
[]
, label [] [ text "Enabled" ]
]
, span [ class "small-info" ]
[ text "Enable or disable this task."
]
]
, div [ class "required field" ]
[ label [] [ text "Mailbox" ]
, Html.map ConnMsg (Comp.Dropdown.view model.connectionModel)
, span [ class "small-info" ]
[ text "The IMAP connection to use when sending notification mails."
]
]
, div [ class "required field" ]
[ label [] [ text "Folders" ]
, Html.map FoldersMsg (Comp.StringListInput.view model.folders model.foldersModel)
, span [ class "small-info" ]
[ text "The folders to go through"
]
]
, Html.map ReceivedHoursMsg
(Comp.IntField.viewWithInfo
"Select mails newer than `now - receivedHours`"
model.receivedHours
"field"
model.receivedHoursModel
)
, div [ class "field" ]
[ label [] [ text "Target folder" ]
, input
[ type_ "text"
, onInput SetTargetFolder
, Maybe.withDefault "" model.targetFolder |> value
]
[]
, span [ class "small-info" ]
[ text "Move all mails successfully submitted into this folder."
]
]
, div [ class "inline field" ]
[ div [ class "ui checkbox" ]
[ input
[ type_ "checkbox"
, onCheck (\_ -> ToggleDeleteMail)
, checked model.deleteMail
]
[]
, label [] [ text "Delete imported mails" ]
]
, span [ class "small-info" ]
[ text "Whether to delete all mails successfully imported into docspell."
]
]
, div [ class "required field" ]
[ label [] [ text "Item direction" ]
, div [ class "grouped fields" ]
[ div [ class "field" ]
[ div [ class "ui radio checkbox" ]
[ input
[ type_ "radio"
, checked (model.direction == Nothing)
, onCheck (\_ -> DirectionMsg Nothing)
]
[]
, label [] [ text "Automatic" ]
]
]
, div [ class "field" ]
[ div [ class "ui radio checkbox" ]
[ input
[ type_ "radio"
, checked (model.direction == Just Incoming)
, onCheck (\_ -> DirectionMsg (Just Incoming))
]
[]
, label [] [ text "Incoming" ]
]
]
, div [ class "field" ]
[ div [ class "ui radio checkbox" ]
[ input
[ type_ "radio"
, checked (model.direction == Just Outgoing)
, onCheck (\_ -> DirectionMsg (Just Outgoing))
]
[]
, label [] [ text "Outgoing" ]
]
]
, span [ class "small-info" ]
[ text "Sets the direction for an item. If you know all mails are incoming or "
, text "outgoing, you can set it here. Otherwise it will be guessed from looking "
, text "at sender and receiver."
]
]
]
, div [ class "required field" ]
[ label []
[ text "Schedule"
, a
[ class "right-float"
, href "https://github.com/eikek/calev#what-are-calendar-events"
, target "_blank"
]
[ i [ class "help icon" ] []
, text "Click here for help"
]
]
, Html.map CalEventMsg
(Comp.CalEventInput.view ""
(Data.Validated.value model.schedule)
model.scheduleModel
)
, span [ class "small-info" ]
[ text "Specify how often and when this task should run. "
, text "Use English 3-letter weekdays. Either a single value, "
, text "a list (ex. 1,2,3), a range (ex. 1..3) or a '*' (meaning all) "
, text "is allowed for each part."
]
]
, div [ class "ui divider" ] []
, div
[ classList
[ ( "ui message", True )
, ( "success", isFormSuccess model )
, ( "error", isFormError model )
, ( "hidden", model.formMsg == Nothing )
]
]
[ Maybe.map .message model.formMsg
|> Maybe.withDefault ""
|> text
]
, button
[ class "ui primary button"
, onClick Submit
]
[ text "Submit"
]
, button
[ class "ui right floated button"
, onClick StartOnce
]
[ text "Start Once"
]
]

View File

@ -0,0 +1,98 @@
module Comp.StringListInput exposing
( ItemAction(..)
, Model
, Msg
, init
, update
, view
)
import Html exposing (..)
import Html.Attributes exposing (..)
import Html.Events exposing (onClick, onInput)
import Util.Maybe
type alias Model =
{ currentInput : String
}
type Msg
= AddString
| RemoveString String
| SetString String
init : Model
init =
{ currentInput = ""
}
--- Update
type ItemAction
= AddAction String
| RemoveAction String
| NoAction
update : Msg -> Model -> ( Model, ItemAction )
update msg model =
case msg of
SetString str ->
( { model | currentInput = str }
, NoAction
)
AddString ->
( { model | currentInput = "" }
, Util.Maybe.fromString model.currentInput
|> Maybe.map AddAction
|> Maybe.withDefault NoAction
)
RemoveString s ->
( model, RemoveAction s )
--- View
view : List String -> Model -> Html Msg
view values model =
let
valueItem s =
div [ class "item" ]
[ a
[ class "ui icon link"
, onClick (RemoveString s)
, href "#"
]
[ i [ class "delete icon" ] []
]
, text s
]
in
div [ class "string-list-input" ]
[ div [ class "ui list" ]
(List.map valueItem values)
, div [ class "ui icon input" ]
[ input
[ placeholder ""
, type_ "text"
, onInput SetString
, value model.currentInput
]
[]
, i
[ class "circular add link icon"
, onClick AddString
]
[]
]
]

View File

@ -7,7 +7,9 @@ module Page.UserSettings.Data exposing
import Comp.ChangePasswordForm import Comp.ChangePasswordForm
import Comp.EmailSettingsManage import Comp.EmailSettingsManage
import Comp.ImapSettingsManage
import Comp.NotificationForm import Comp.NotificationForm
import Comp.ScanMailboxForm
import Data.Flags exposing (Flags) import Data.Flags exposing (Flags)
@ -15,7 +17,9 @@ type alias Model =
{ currentTab : Maybe Tab { currentTab : Maybe Tab
, changePassModel : Comp.ChangePasswordForm.Model , changePassModel : Comp.ChangePasswordForm.Model
, emailSettingsModel : Comp.EmailSettingsManage.Model , emailSettingsModel : Comp.EmailSettingsManage.Model
, imapSettingsModel : Comp.ImapSettingsManage.Model
, notificationModel : Comp.NotificationForm.Model , notificationModel : Comp.NotificationForm.Model
, scanMailboxModel : Comp.ScanMailboxForm.Model
} }
@ -24,14 +28,18 @@ emptyModel flags =
{ currentTab = Nothing { currentTab = Nothing
, changePassModel = Comp.ChangePasswordForm.emptyModel , changePassModel = Comp.ChangePasswordForm.emptyModel
, emailSettingsModel = Comp.EmailSettingsManage.emptyModel , emailSettingsModel = Comp.EmailSettingsManage.emptyModel
, imapSettingsModel = Comp.ImapSettingsManage.emptyModel
, notificationModel = Tuple.first (Comp.NotificationForm.init flags) , notificationModel = Tuple.first (Comp.NotificationForm.init flags)
, scanMailboxModel = Tuple.first (Comp.ScanMailboxForm.init flags)
} }
type Tab type Tab
= ChangePassTab = ChangePassTab
| EmailSettingsTab | EmailSettingsTab
| ImapSettingsTab
| NotificationTab | NotificationTab
| ScanMailboxTab
type Msg type Msg
@ -39,3 +47,5 @@ type Msg
| ChangePassMsg Comp.ChangePasswordForm.Msg | ChangePassMsg Comp.ChangePasswordForm.Msg
| EmailSettingsMsg Comp.EmailSettingsManage.Msg | EmailSettingsMsg Comp.EmailSettingsManage.Msg
| NotificationMsg Comp.NotificationForm.Msg | NotificationMsg Comp.NotificationForm.Msg
| ImapSettingsMsg Comp.ImapSettingsManage.Msg
| ScanMailboxMsg Comp.ScanMailboxForm.Msg

View File

@ -2,7 +2,9 @@ module Page.UserSettings.Update exposing (update)
import Comp.ChangePasswordForm import Comp.ChangePasswordForm
import Comp.EmailSettingsManage import Comp.EmailSettingsManage
import Comp.ImapSettingsManage
import Comp.NotificationForm import Comp.NotificationForm
import Comp.ScanMailboxForm
import Data.Flags exposing (Flags) import Data.Flags exposing (Flags)
import Page.UserSettings.Data exposing (..) import Page.UserSettings.Data exposing (..)
@ -24,6 +26,13 @@ update flags msg model =
in in
( { m | emailSettingsModel = em }, Cmd.map EmailSettingsMsg c ) ( { m | emailSettingsModel = em }, Cmd.map EmailSettingsMsg c )
ImapSettingsTab ->
let
( em, c ) =
Comp.ImapSettingsManage.init flags
in
( { m | imapSettingsModel = em }, Cmd.map ImapSettingsMsg c )
ChangePassTab -> ChangePassTab ->
( m, Cmd.none ) ( m, Cmd.none )
@ -34,6 +43,14 @@ update flags msg model =
(Tuple.second (Comp.NotificationForm.init flags)) (Tuple.second (Comp.NotificationForm.init flags))
in in
( m, initCmd ) ( m, initCmd )
ScanMailboxTab ->
let
initCmd =
Cmd.map ScanMailboxMsg
(Tuple.second (Comp.ScanMailboxForm.init flags))
in
( m, initCmd )
in in
( m2, cmd ) ( m2, cmd )
@ -51,6 +68,13 @@ update flags msg model =
in in
( { model | emailSettingsModel = m2 }, Cmd.map EmailSettingsMsg c2 ) ( { model | emailSettingsModel = m2 }, Cmd.map EmailSettingsMsg c2 )
ImapSettingsMsg m ->
let
( m2, c2 ) =
Comp.ImapSettingsManage.update flags m model.imapSettingsModel
in
( { model | imapSettingsModel = m2 }, Cmd.map ImapSettingsMsg c2 )
NotificationMsg lm -> NotificationMsg lm ->
let let
( m2, c2 ) = ( m2, c2 ) =
@ -59,3 +83,12 @@ update flags msg model =
( { model | notificationModel = m2 } ( { model | notificationModel = m2 }
, Cmd.map NotificationMsg c2 , Cmd.map NotificationMsg c2
) )
ScanMailboxMsg lm ->
let
( m2, c2 ) =
Comp.ScanMailboxForm.update flags lm model.scanMailboxModel
in
( { model | scanMailboxModel = m2 }
, Cmd.map ScanMailboxMsg c2
)

View File

@ -2,7 +2,9 @@ module Page.UserSettings.View exposing (view)
import Comp.ChangePasswordForm import Comp.ChangePasswordForm
import Comp.EmailSettingsManage import Comp.EmailSettingsManage
import Comp.ImapSettingsManage
import Comp.NotificationForm import Comp.NotificationForm
import Comp.ScanMailboxForm
import Html exposing (..) import Html exposing (..)
import Html.Attributes exposing (..) import Html.Attributes exposing (..)
import Html.Events exposing (onClick) import Html.Events exposing (onClick)
@ -15,13 +17,15 @@ view model =
div [ class "usersetting-page ui padded grid" ] div [ class "usersetting-page ui padded grid" ]
[ div [ class "sixteen wide mobile four wide tablet four wide computer column" ] [ div [ class "sixteen wide mobile four wide tablet four wide computer column" ]
[ h4 [ class "ui top attached ablue-comp header" ] [ h4 [ class "ui top attached ablue-comp header" ]
[ text "User" [ text "User Settings"
] ]
, div [ class "ui attached fluid segment" ] , div [ class "ui attached fluid segment" ]
[ div [ class "ui fluid vertical secondary menu" ] [ div [ class "ui fluid vertical secondary menu" ]
[ makeTab model ChangePassTab "Change Password" "user secret icon" [ makeTab model ChangePassTab "Change Password" "user secret icon"
, makeTab model EmailSettingsTab "E-Mail Settings" "mail icon" , makeTab model EmailSettingsTab "E-Mail Settings (SMTP)" "mail icon"
, makeTab model NotificationTab "Notifications" "bullhorn icon" , makeTab model ImapSettingsTab "E-Mail Settings (IMAP)" "mail icon"
, makeTab model NotificationTab "Notification Task" "bullhorn icon"
, makeTab model ScanMailboxTab "Scan Mailbox Task" "envelope open outline icon"
] ]
] ]
] ]
@ -37,6 +41,12 @@ view model =
Just NotificationTab -> Just NotificationTab ->
viewNotificationForm model viewNotificationForm model
Just ImapSettingsTab ->
viewImapSettings model
Just ScanMailboxTab ->
viewScanMailboxForm model
Nothing -> Nothing ->
[] []
) )
@ -61,13 +71,25 @@ viewEmailSettings model =
[ h2 [ class "ui header" ] [ h2 [ class "ui header" ]
[ i [ class "mail icon" ] [] [ i [ class "mail icon" ] []
, div [ class "content" ] , div [ class "content" ]
[ text "E-Mail Settings" [ text "E-Mail Settings (Smtp)"
] ]
] ]
, Html.map EmailSettingsMsg (Comp.EmailSettingsManage.view model.emailSettingsModel) , Html.map EmailSettingsMsg (Comp.EmailSettingsManage.view model.emailSettingsModel)
] ]
viewImapSettings : Model -> List (Html Msg)
viewImapSettings model =
[ h2 [ class "ui header" ]
[ i [ class "mail icon" ] []
, div [ class "content" ]
[ text "E-Mail Settings (Imap)"
]
]
, Html.map ImapSettingsMsg (Comp.ImapSettingsManage.view model.imapSettingsModel)
]
viewChangePassword : Model -> List (Html Msg) viewChangePassword : Model -> List (Html Msg)
viewChangePassword model = viewChangePassword model =
[ h2 [ class "ui header" ] [ h2 [ class "ui header" ]
@ -89,15 +111,45 @@ viewNotificationForm model =
] ]
] ]
, p [] , p []
[ text "Docspell can notify you once the due dates of your items come closer. " [ text """
, text "Notification is done via e-mail. You need to provide a connection in " Docspell can notify you once the due dates of your items
, text "your e-mail settings." come closer. Notification is done via e-mail. You need to
provide a connection in your e-mail settings."""
] ]
, p [] , p []
[ text "Each time this is executed, docspell finds all items that are due in " [ text "Docspell finds all items that are due in "
, em [] [ text "Remind Days" ] , em [] [ text "Remind Days" ]
, text " days." , text " days and sends this list via e-mail."
] ]
, Html.map NotificationMsg , Html.map NotificationMsg
(Comp.NotificationForm.view "segment" model.notificationModel) (Comp.NotificationForm.view "segment" model.notificationModel)
] ]
viewScanMailboxForm : Model -> List (Html Msg)
viewScanMailboxForm model =
[ h2 [ class "ui header" ]
[ i [ class "ui envelope open outline icon" ] []
, div [ class "content" ]
[ text "Scan Mailbox"
]
]
, p []
[ text "Docspell can scan folders of your mailbox to import your mails. "
, text "You need to provide a connection in "
, text "your e-mail (imap) settings."
]
, p []
[ text """
Docspell goes through all configured folders and imports
mails matching the search criteria. Mails are skipped if
they were imported in a previous run and the corresponding
items still exist. After submitting a mail into docspell,
you can choose to move it to another folder, to delete it
or to just leave it there. In the latter case you should
adjust the schedule to avoid reading over the same mails
again."""
]
, Html.map ScanMailboxMsg
(Comp.ScanMailboxForm.view "segment" model.scanMailboxModel)
]