Skip to content

Commit

Permalink
Removed Unused imports
Browse files Browse the repository at this point in the history
  • Loading branch information
hnaderi committed Nov 14, 2023
1 parent 8e9627c commit af55c4f
Show file tree
Hide file tree
Showing 61 changed files with 2 additions and 145 deletions.
1 change: 0 additions & 1 deletion examples/src/main/scala/Example1.scala
Original file line number Diff line number Diff line change
Expand Up @@ -102,7 +102,6 @@ object Application extends IOApp.Simple {

val application = database.flatMap(backendRes).use { backend =>
val service = backend.compile(app)
val srv2 = backend.compile(CounterService())

service(
CommandMessage("abc", Instant.now, "a", "receive")
Expand Down
2 changes: 0 additions & 2 deletions mdoc-plantuml/src/main/scala/PlantumlModifier.scala
Original file line number Diff line number Diff line change
Expand Up @@ -18,8 +18,6 @@ package ir.hnaderi.mdocPlantuml

import mdoc.Reporter
import mdoc.StringModifier
import net.sourceforge.plantuml.FileFormat
import net.sourceforge.plantuml.FileFormatOption
import net.sourceforge.plantuml.SourceStringReader

import scala.meta.inputs.Input
Expand Down
1 change: 0 additions & 1 deletion modules/backend-tests/js/src/main/scala/StorageSuite.scala
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,6 @@ package tests

import cats.effect.IO
import cats.effect.kernel.Resource
import edomata.backend.*
import munit.CatsEffectSuite
import munit.Location

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,6 @@ package tests

import cats.effect.IO
import cats.effect.kernel.Resource
import edomata.backend.*
import munit.CatsEffectSuite
import munit.Location

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,6 @@ package tests

import cats.effect.IO
import cats.effect.kernel.Resource
import edomata.backend.*
import munit.CatsEffectSuite
import munit.Location

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,6 @@ package tests

import cats.effect.IO
import cats.effect.kernel.Resource
import cats.effect.std.UUIDGen
import cats.implicits.*
import edomata.backend.BackendError
import edomata.backend.cqrs.*
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -25,7 +25,6 @@ import edomata.backend.BackendError
import edomata.core.CommandMessage
import edomata.core.Edomaton
import edomata.core.ResponseD
import munit.CatsEffectSuite
import tests.TestDomain.given_ModelTC_State_Event_Rejection

import java.time.Instant
Expand Down
4 changes: 0 additions & 4 deletions modules/backend/src/main/scala/Backend.scala
Original file line number Diff line number Diff line change
Expand Up @@ -16,12 +16,8 @@

package edomata.backend

import cats.effect.kernel.Async
import cats.effect.kernel.Resource
import edomata.core.*

import scala.concurrent.duration.*

object Backend {
def builder[C, S, E, R, N](
domain: Domain[C, S, E, R, N]
Expand Down
1 change: 0 additions & 1 deletion modules/backend/src/main/scala/CommandStore.scala
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,6 @@
package edomata.backend

import cats.Monad
import cats.effect.Concurrent
import cats.effect.kernel.Async
import cats.effect.kernel.Ref
import cats.implicits.*
Expand Down
1 change: 0 additions & 1 deletion modules/backend/src/main/scala/LRUCache.scala
Original file line number Diff line number Diff line change
Expand Up @@ -16,7 +16,6 @@

package edomata.backend

import cats.effect.Concurrent
import cats.effect.Resource
import cats.effect.Sync
import cats.effect.kernel.Async
Expand Down
1 change: 0 additions & 1 deletion modules/backend/src/main/scala/Outbox.scala
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,6 @@ import edomata.core.*
import fs2.Stream

import java.time.OffsetDateTime
import java.util.UUID

trait OutboxReader[F[_], N] {
def read: Stream[F, OutboxItem[N]]
Expand Down
1 change: 0 additions & 1 deletion modules/backend/src/main/scala/OutboxConsumer.scala
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,6 @@ package edomata.backend
import cats.Monad
import cats.data.NonEmptyChain
import cats.implicits.*
import edomata.backend.OutboxItem
import fs2.Stream
import fs2.Stream.*

Expand Down
4 changes: 0 additions & 4 deletions modules/backend/src/main/scala/cqrs/Backend.scala
Original file line number Diff line number Diff line change
Expand Up @@ -17,13 +17,9 @@
package edomata.backend
package cqrs

import cats.Applicative
import cats.Monad
import cats.data.NonEmptyChain
import cats.effect.kernel.Async
import cats.effect.kernel.Resource
import cats.effect.std.Random
import cats.implicits.*
import edomata.core.*

import scala.concurrent.duration.*
Expand Down
1 change: 0 additions & 1 deletion modules/backend/src/main/scala/cqrs/Storage.scala
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,6 @@
package edomata.backend
package cqrs

import cats.data.NonEmptyChain
import cats.effect.kernel.Resource
import edomata.core.StateModelTC

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,6 @@ import cats.Monad
import cats.data.EitherNec
import cats.data.NonEmptyChain
import cats.effect.Temporal
import cats.effect.implicits.*
import cats.implicits.*
import edomata.core.*

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -17,13 +17,8 @@
package edomata.backend
package eventsourcing

import cats.data.NonEmptyChain
import edomata.core.*
import fs2.Stream

import java.time.OffsetDateTime
import java.util.UUID

trait JournalReader[F[_], E] {
def readStream(streamId: StreamId): Stream[F, EventMessage[E]]
def readStreamAfter(
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -24,9 +24,6 @@ import edomata.core.*
import fs2.Pipe
import fs2.Stream

import java.time.OffsetDateTime
import java.util.UUID

type CommandState[S, E, R] = AggregateState[S, E, R] |
CommandState.Redundant.type

Expand Down
3 changes: 0 additions & 3 deletions modules/backend/src/test/scala/FakeOutboxReader.scala
Original file line number Diff line number Diff line change
Expand Up @@ -16,11 +16,8 @@

package edomata.backend

import cats.data.Chain
import cats.data.NonEmptyChain
import cats.effect.IO
import cats.effect.kernel.Ref
import edomata.core.*
import fs2.Stream

import FakeOutboxReader.*
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -16,15 +16,11 @@

package edomata.backend

import cats.data.Chain
import cats.data.NonEmptyChain
import cats.effect.IO
import cats.implicits.*
import edomata.core.*
import munit.CatsEffectSuite

import java.time.Instant
import scala.collection.immutable.HashSet

import InMemoryCommandStoreSuite.*

Expand Down
2 changes: 0 additions & 2 deletions modules/backend/src/test/scala/OutboxConsumerSuite.scala
Original file line number Diff line number Diff line change
Expand Up @@ -16,14 +16,12 @@

package edomata.backend

import cats.data.NonEmptyChain
import cats.effect.IO
import cats.implicits.*
import edomata.core.MessageMetadata
import fs2.Stream
import fs2.Stream.*
import munit.CatsEffectSuite
import munit.FunSuite

import java.time.OffsetDateTime

Expand Down
2 changes: 0 additions & 2 deletions modules/backend/src/test/scala/cqrs/CommandHandlerSuite.scala
Original file line number Diff line number Diff line change
Expand Up @@ -27,13 +27,11 @@ import munit.CatsEffectSuite

import java.time.Instant
import java.time.OffsetDateTime
import java.util.UUID
import scala.concurrent.duration.*

import CommandHandlerSuite.*
import SUT.given_StateModelTC_State
import FakeRepository.Interaction
import cats.effect.std.Random.apply
import cats.effect.std.Random
import edomata.backend.BackendError
import edomata.backend.CommandState.Redundant
Expand Down
2 changes: 0 additions & 2 deletions modules/backend/src/test/scala/cqrs/FakeRepository.scala
Original file line number Diff line number Diff line change
Expand Up @@ -19,11 +19,9 @@ package edomata.backend.cqrs
import cats.data.*
import cats.effect.IO
import cats.effect.kernel.Ref
import cats.implicits.*
import edomata.backend.cqrs.FakeRepository.*
import edomata.backend.{SeqNr, StreamId}
import edomata.core.*
import edomata.syntax.all.*
import munit.CatsEffectAssertions.*

final class FakeRepository[State, Event](
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,6 @@ package cqrs

import cats.effect.IO
import cats.effect.testkit.TestControl
import cats.implicits.*
import fs2.Chunk
import fs2.Stream
import munit.CatsEffectSuite
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -29,7 +29,6 @@ import munit.CatsEffectSuite

import java.time.Instant
import java.time.OffsetDateTime
import java.util.UUID
import scala.concurrent.duration.*

import CommandHandlerSuite.*
Expand Down
1 change: 0 additions & 1 deletion modules/backend/src/test/scala/eventsourcing/Doubles.scala
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,6 @@ import cats.data.Chain
import cats.data.NonEmptyChain
import cats.effect.IO
import cats.effect.kernel.Ref
import cats.implicits.*
import edomata.backend.eventsourcing.AggregateState.Valid
import edomata.core.*
import fs2.Chunk
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,6 @@ package eventsourcing

import cats.effect.IO
import cats.effect.testkit.TestControl
import cats.implicits.*
import fs2.Chunk
import fs2.Stream
import munit.CatsEffectSuite
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,6 @@ package edomata.backend
package eventsourcing

import cats.effect.IO
import cats.effect.kernel.Resource
import cats.effect.testkit.TestControl
import cats.implicits.*
import munit.CatsEffectSuite
Expand Down
1 change: 0 additions & 1 deletion modules/core/src/main/scala/Decision.scala
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,6 @@
package edomata.core

import cats.Applicative
import cats.Bifunctor
import cats.Eval
import cats.MonadError
import cats.Traverse
Expand Down
2 changes: 0 additions & 2 deletions modules/core/src/main/scala/DomainCompiler.scala
Original file line number Diff line number Diff line change
Expand Up @@ -23,8 +23,6 @@ import cats.data.EitherNec
import cats.data.NonEmptyChain
import cats.implicits.*

import java.time.OffsetDateTime
import java.time.ZoneOffset
import scala.util.NotGiven

type DomainService[F[_], C, R] = C => F[EitherNec[R, Unit]]
Expand Down
1 change: 0 additions & 1 deletion modules/core/src/main/scala/RaiseError.scala
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,6 @@ package edomata.core

import cats.data.NonEmptyChainImpl.Type
import cats.data.*
import cats.implicits.*

trait RaiseError[F[+_], R] {
def fold[O, A](v: F[O])(err: NonEmptyChain[R] => A, value: O => A): A
Expand Down
1 change: 0 additions & 1 deletion modules/core/src/main/scala/RequestContext.scala
Original file line number Diff line number Diff line change
Expand Up @@ -16,7 +16,6 @@

package edomata.core

import cats.data.NonEmptyChain
import cats.implicits.*

import java.time.Instant
Expand Down
1 change: 0 additions & 1 deletion modules/core/src/main/scala/ResponseD.scala
Original file line number Diff line number Diff line change
Expand Up @@ -18,7 +18,6 @@ package edomata.core

import cats.*
import cats.data.*
import cats.implicits.*

/** Representation of programs that decide and emit notifications
*
Expand Down
3 changes: 0 additions & 3 deletions modules/core/src/main/scala/ResponseE.scala
Original file line number Diff line number Diff line change
Expand Up @@ -19,9 +19,6 @@ package edomata.core
import cats.*
import cats.data.*
import cats.implicits.*
import cats.kernel.Eq

import scala.annotation.tailrec

/** Representation of programs that decide and emit notifications
*
Expand Down
2 changes: 0 additions & 2 deletions modules/core/src/test/scala/Helpers.scala
Original file line number Diff line number Diff line change
Expand Up @@ -17,12 +17,10 @@
package tests

import cats.Functor
import cats.Monad
import cats.data.NonEmptyChain
import cats.implicits.*
import org.scalacheck.Arbitrary
import org.scalacheck.Gen
import org.scalacheck.Prop.forAll

private[tests] def necOf[T](g: Gen[T]): Gen[NonEmptyChain[T]] =
Gen
Expand Down
1 change: 0 additions & 1 deletion modules/core/src/test/scala/action/ActionSuite.scala
Original file line number Diff line number Diff line change
Expand Up @@ -132,7 +132,6 @@ class ActionSuite extends DisciplineSuite {
val c = a >> b

val ares = a.run.value
val bres = b.run.value
val cres = c.run.value

assertEquals(cres.result, ares.result) // just for doc
Expand Down
2 changes: 0 additions & 2 deletions modules/core/src/test/scala/decision/DecisionSuite.scala
Original file line number Diff line number Diff line change
Expand Up @@ -17,12 +17,10 @@
package tests
package decision

import cats.Monad
import cats.data.*
import cats.implicits.*
import cats.kernel.laws.discipline.EqTests
import cats.kernel.laws.discipline.SerializableTests
import cats.laws.discipline.FunctorTests
import cats.laws.discipline.MonadErrorTests
import cats.laws.discipline.TraverseTests
import cats.laws.discipline.arbitrary.catsLawsCogenForNonEmptyChain
Expand Down
1 change: 0 additions & 1 deletion modules/core/src/test/scala/decision/Generators.scala
Original file line number Diff line number Diff line change
Expand Up @@ -17,7 +17,6 @@
package tests
package decision

import cats.data.NonEmptyChain
import org.scalacheck.Arbitrary
import org.scalacheck.Gen
import edomata.core.Decision
Expand Down
1 change: 0 additions & 1 deletion modules/core/src/test/scala/decisiont/DecisionTSuite.scala
Original file line number Diff line number Diff line change
Expand Up @@ -19,7 +19,6 @@ package decisiont

import cats.Applicative
import cats.Eval
import cats.data.NonEmptyChain
import cats.implicits.*
import cats.kernel.laws.discipline.EqTests
import cats.laws.discipline.MonadTests
Expand Down
2 changes: 0 additions & 2 deletions modules/core/src/test/scala/edomaton/EdomatonSuite.scala
Original file line number Diff line number Diff line change
Expand Up @@ -22,12 +22,10 @@ import cats.data.*
import cats.implicits.*
import cats.kernel.laws.discipline.EqTests
import cats.laws.discipline.*
import cats.laws.discipline.arbitrary.*
import cats.laws.discipline.eq.*
import munit.*
import org.scalacheck.Arbitrary
import org.scalacheck.Gen
import org.scalacheck.Prop.forAll
import edomata.core.*
import tests.decision.Generators

Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -16,18 +16,11 @@

package tests.responset

import cats.Monad
import cats.data.*
import cats.implicits.*
import cats.kernel.laws.discipline.EqTests
import cats.laws.discipline.MonadTests
import cats.laws.discipline.TraverseTests
import cats.laws.discipline.arbitrary.catsLawsArbitraryForNonEmptyChain
import cats.laws.discipline.arbitrary.catsLawsCogenForNonEmptyChain
import munit.*
import org.scalacheck.Arbitrary
import org.scalacheck.Gen
import org.scalacheck.Prop.forAll
import edomata.core.*

import tests.decision.Generators.*
Expand Down
Loading

0 comments on commit af55c4f

Please sign in to comment.