Merge pull request #1178 from eikek/fixups

Fixups
This commit is contained in:
mergify[bot] 2021-11-16 22:09:39 +00:00 committed by GitHub
commit 75679cd681
No known key found for this signature in database
GPG Key ID: 4AEE18F83AFDEB23
12 changed files with 46 additions and 39 deletions

View File

@ -6,7 +6,9 @@
package docspell.backend.ops
import cats.Applicative
import cats.effect._
import cats.implicits._
import docspell.backend.msg.{CancelJob, Topics}
import docspell.common.Ident
@ -20,13 +22,13 @@ trait OJoex[F[_]] {
}
object OJoex {
def apply[F[_]](pubSub: PubSubT[F]): Resource[F, OJoex[F]] =
def apply[F[_]: Applicative](pubSub: PubSubT[F]): Resource[F, OJoex[F]] =
Resource.pure[F, OJoex[F]](new OJoex[F] {
def notifyAllNodes: F[Unit] =
pubSub.publish1IgnoreErrors(Topics.jobsNotify, ())
pubSub.publish1IgnoreErrors(Topics.jobsNotify, ()).as(())
def cancelJob(job: Ident, worker: Ident): F[Unit] =
pubSub.publish1IgnoreErrors(CancelJob.topic, CancelJob(job, worker))
pubSub.publish1IgnoreErrors(CancelJob.topic, CancelJob(job, worker)).as(())
})
}

View File

@ -32,7 +32,6 @@ import docspell.joex.process.ReProcessItem
import docspell.joex.scanmailbox._
import docspell.joex.scheduler._
import docspell.joex.updatecheck._
import docspell.joexapi.client.JoexClient
import docspell.pubsub.api.{PubSub, PubSubT}
import docspell.store.Store
import docspell.store.queue._
@ -127,7 +126,6 @@ object JoexAppImpl {
): Resource[F, JoexApp[F]] =
for {
pstore <- PeriodicTaskStore.create(store)
client = JoexClient(httpClient)
pubSubT = PubSubT(
pubSub,
Logger.log4s(org.log4s.getLogger(s"joex-${cfg.appId.id}"))
@ -271,7 +269,7 @@ object JoexAppImpl {
sch,
queue,
pstore,
client
joex
)
app = new JoexAppImpl(cfg, store, queue, pubSubT, pstore, termSignal, sch, psch)
appR <- Resource.make(app.init.map(_ => app))(_.initShutdown)

View File

@ -10,7 +10,7 @@ import cats.effect._
import fs2._
import fs2.concurrent.SignallingRef
import docspell.joexapi.client.JoexClient
import docspell.backend.ops.OJoex
import docspell.store.queue._
/** A periodic scheduler takes care to submit periodic tasks to the job queue.
@ -40,7 +40,7 @@ object PeriodicScheduler {
sch: Scheduler[F],
queue: JobQueue[F],
store: PeriodicTaskStore[F],
client: JoexClient[F]
joex: OJoex[F]
): Resource[F, PeriodicScheduler[F]] =
for {
waiter <- Resource.eval(SignallingRef(true))
@ -50,7 +50,7 @@ object PeriodicScheduler {
sch,
queue,
store,
client,
joex,
waiter,
state
)

View File

@ -11,10 +11,10 @@ import cats.implicits._
import fs2._
import fs2.concurrent.SignallingRef
import docspell.backend.ops.OJoex
import docspell.common._
import docspell.common.syntax.all._
import docspell.joex.scheduler.PeriodicSchedulerImpl.State
import docspell.joexapi.client.JoexClient
import docspell.store.queue._
import docspell.store.records.RPeriodicTask
@ -26,7 +26,7 @@ final class PeriodicSchedulerImpl[F[_]: Async](
sch: Scheduler[F],
queue: JobQueue[F],
store: PeriodicTaskStore[F],
client: JoexClient[F],
joex: OJoex[F],
waiter: SignallingRef[F, Boolean],
state: SignallingRef[F, State[F]]
) extends PeriodicScheduler[F] {
@ -119,9 +119,7 @@ final class PeriodicSchedulerImpl[F[_]: Async](
}
def notifyJoex: F[Unit] =
sch.notifyChange *> store.findJoexNodes.flatMap(
_.traverse(n => client.notifyJoexIgnoreErrors(n.url)).map(_ => ())
)
sch.notifyChange *> joex.notifyAllNodes
def scheduleNotify(pj: RPeriodicTask): F[Unit] =
Timestamp

View File

@ -15,7 +15,7 @@ import docspell.common.{Ident, Timestamp}
import io.circe.Json
trait PubSub[F[_]] {
def publish1(topic: Topic, msg: Json): F[MessageHead]
def publish1(topic: Topic, msg: Json): F[F[MessageHead]]
def publish(topic: Topic): Pipe[F, Json, MessageHead]
@ -24,8 +24,10 @@ trait PubSub[F[_]] {
object PubSub {
def noop[F[_]: Applicative]: PubSub[F] =
new PubSub[F] {
def publish1(topic: Topic, msg: Json): F[MessageHead] =
Applicative[F].pure(MessageHead(Ident.unsafe("0"), Timestamp.Epoch, topic))
def publish1(topic: Topic, msg: Json): F[F[MessageHead]] =
Applicative[F].pure(
Applicative[F].pure(MessageHead(Ident.unsafe("0"), Timestamp.Epoch, topic))
)
def publish(topic: Topic): Pipe[F, Json, MessageHead] =
_ => Stream.empty

View File

@ -16,9 +16,9 @@ import docspell.common.Logger
trait PubSubT[F[_]] {
def publish1[A](topic: TypedTopic[A], msg: A): F[MessageHead]
def publish1[A](topic: TypedTopic[A], msg: A): F[F[MessageHead]]
def publish1IgnoreErrors[A](topic: TypedTopic[A], msg: A): F[Unit]
def publish1IgnoreErrors[A](topic: TypedTopic[A], msg: A): F[F[Unit]]
def publish[A](topic: TypedTopic[A]): Pipe[F, A, MessageHead]
@ -37,15 +37,15 @@ object PubSubT {
def apply[F[_]: Async](pubSub: PubSub[F], logger: Logger[F]): PubSubT[F] =
new PubSubT[F] {
def publish1[A](topic: TypedTopic[A], msg: A): F[MessageHead] =
def publish1[A](topic: TypedTopic[A], msg: A): F[F[MessageHead]] =
pubSub.publish1(topic.topic, topic.codec(msg))
def publish1IgnoreErrors[A](topic: TypedTopic[A], msg: A): F[Unit] =
publish1(topic, msg).attempt.flatMap {
def publish1IgnoreErrors[A](topic: TypedTopic[A], msg: A): F[F[Unit]] =
publish1(topic, msg).map(_.attempt.flatMap {
case Right(_) => ().pure[F]
case Left(ex) =>
logger.error(ex)(s"Error publishing to topic ${topic.topic.name}: $msg")
}
})
def publish[A](topic: TypedTopic[A]): Pipe[F, A, MessageHead] =
_.map(topic.codec.apply).through(pubSub.publish(topic.topic))

View File

@ -65,7 +65,10 @@ final class NaivePubSub[F[_]: Async](
def withClient(client: Client[F]): NaivePubSub[F] =
new NaivePubSub[F](cfg, state, store, client)
def publish1(topic: Topic, msgBody: Json): F[MessageHead] =
def publish1(topic: Topic, msgBody: Json): F[F[MessageHead]] =
Async[F].start(publish0(topic, msgBody)).map(fiber => fiber.joinWithNever)
def publish0(topic: Topic, msgBody: Json): F[MessageHead] =
for {
head <- mkMessageHead(topic)
msg = Message(head, msgBody)
@ -78,7 +81,7 @@ final class NaivePubSub[F[_]: Async](
def publish(topic: Topic): Pipe[F, Json, MessageHead] =
ms => //TODO Do some optimization by grouping messages to the same topic
ms.evalMap(publish1(topic, _))
ms.evalMap(publish0(topic, _))
def subscribe(topics: NonEmptyList[Topic]): Stream[F, Message[Json]] =
(for {

View File

@ -44,7 +44,7 @@ class NaivePubSubTest extends CatsEffectSuite with Fixtures {
for {
res <- subscribe(ps, Topics.jobSubmitted)
(received, _, subFiber) = res
headSend <- ps.publish1(Topics.jobSubmitted, JobSubmittedMsg("hello".id))
headSend <- ps.publish1(Topics.jobSubmitted, JobSubmittedMsg("hello".id)).flatten
outcome <- subFiber.join
msgRec <- received.get
_ = assert(outcome.isSuccess)

View File

@ -24,6 +24,7 @@ type alias Texts =
, authFailed : String
, fulltextPlaceholder : String
, powerSearchPlaceholder : String
, normalSearchPlaceholder : String
, extendedSearch : String
}
@ -39,6 +40,7 @@ gb =
, fulltextPlaceholder = "Fulltext search"
, powerSearchPlaceholder = "Extended search"
, extendedSearch = "Extended search query"
, normalSearchPlaceholder = "Search"
}
@ -53,4 +55,5 @@ de =
, fulltextPlaceholder = "Volltextsuche"
, powerSearchPlaceholder = "Erweiterte Suche"
, extendedSearch = "Erweiterte Suchanfrage"
, normalSearchPlaceholder = "Suche"
}

View File

@ -10,7 +10,7 @@ module Page.Share.Menubar exposing (view)
import Comp.Basic as B
import Comp.MenuBar as MB
import Comp.PowerSearchInput
import Comp.SearchMenu
import Data.Flags exposing (Flags)
import Html exposing (..)
import Html.Attributes exposing (..)
import Html.Events exposing (onClick, onInput)
@ -20,16 +20,9 @@ import Styles as S
import Util.Html
view : Texts -> Model -> Html Msg
view texts model =
view : Texts -> Flags -> Model -> Html Msg
view texts flags model =
let
btnStyle =
S.secondaryBasicButton ++ " text-sm"
searchInput =
Comp.SearchMenu.textSearchString
model.searchMenuModel.textSearchModel
powerSearchBar =
div [ class "flex-grow flex flex-col relative" ]
[ div
@ -67,7 +60,11 @@ view texts model =
[ type_ "text"
, class S.textInput
, class "text-sm"
, placeholder texts.fulltextPlaceholder
, if flags.config.fullTextSearchEnabled then
placeholder texts.fulltextPlaceholder
else
placeholder texts.normalSearchPlaceholder
, onInput SetContentSearch
, value (Maybe.withDefault "" model.contentSearch)
, Util.Html.onKeyUpCode ContentSearchKey

View File

@ -214,7 +214,11 @@ makeSearchCmd flags model =
model.powerSearchInput.input
SearchBarContent ->
Maybe.map (Q.Contents >> Q.render) model.contentSearch
if flags.config.fullTextSearchEnabled then
Maybe.map (Q.Contents >> Q.render) model.contentSearch
else
Maybe.map (Q.AllNames >> Q.render) model.contentSearch
]
request mq =

View File

@ -80,7 +80,7 @@ mainContent texts flags settings shareId model =
]
[ text <| Maybe.withDefault "" model.verifyResult.name
]
, Menubar.view texts model
, Menubar.view texts flags model
, errorMessage texts model
, Results.view texts settings flags shareId model
]