Skip to content

Commit

Permalink
renamed ByteBufferCleaner to ByteBufferSweeper
Browse files Browse the repository at this point in the history
  • Loading branch information
simerplaha committed Aug 13, 2020
1 parent 8300d2f commit 8e3fccb
Show file tree
Hide file tree
Showing 38 changed files with 101 additions and 101 deletions.
Original file line number Diff line number Diff line change
Expand Up @@ -32,7 +32,7 @@ import swaydb.IOValues._
import swaydb.core.CommonAssertions.randomIOStrategy
import swaydb.core.TestData._
import swaydb.core.actor.FileSweeper
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.segment.format.a.block.reader.BlockRefReader
import swaydb.core.util.{Benchmark, BlockCacheFileIDGenerator, Bytes}
import swaydb.core.{TestBase, TestSweeper}
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -27,7 +27,7 @@ package swaydb.core.segment.format.a.block
import swaydb.IOValues._
import swaydb.core.TestData._
import swaydb.core.actor.FileSweeper
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, DBFile}
import swaydb.core.io.reader.FileReader
import swaydb.core.segment.format.a.block.reader.{BlockReader, BlockRefReader}
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -29,7 +29,7 @@ import swaydb.core.RunThis._
import swaydb.core.TestData._
import swaydb.core.TestSweeper.fileSweeper
import swaydb.core.actor.FileSweeper
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.util.{Benchmark, BlockCacheFileIDGenerator}
import swaydb.core.{TestBase, TestSweeper}
import swaydb.data.util.OperatingSystem
Expand Down
6 changes: 3 additions & 3 deletions core/src/main/scala/swaydb/core/CoreInitializer.scala
Original file line number Diff line number Diff line change
Expand Up @@ -31,9 +31,9 @@ import swaydb.Error.Level.ExceptionHandler
import swaydb.core.CoreShutdown.shutdown
import swaydb.core.actor.{FileSweeper, MemorySweeper}
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.Effect._
import swaydb.core.io.file.{BlockCache, BufferCleaner}
import swaydb.core.io.file.{BlockCache, ByteBufferSweeper}
import swaydb.core.level.compaction._
import swaydb.core.level.compaction.throttle.{ThrottleCompactor, ThrottleState}
import swaydb.core.level.zero.LevelZero
Expand Down Expand Up @@ -152,7 +152,7 @@ private[core] object CoreInitializer extends LazyLogging {
ThrottleCompactor

implicit val bufferCleaner: ByteBufferSweeperActor =
BufferCleaner()(Scheduler()(fileSweeper.ec))
ByteBufferSweeper()(Scheduler()(fileSweeper.ec))

def createLevel(id: Long,
nextLevel: Option[NextLevel],
Expand Down
6 changes: 3 additions & 3 deletions core/src/main/scala/swaydb/core/CoreShutdown.scala
Original file line number Diff line number Diff line change
Expand Up @@ -26,8 +26,8 @@ package swaydb.core

import com.typesafe.scalalogging.LazyLogging
import swaydb.core.actor.{FileSweeper, MemorySweeper}
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, BufferCleaner}
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, ByteBufferSweeper}
import swaydb.core.level.compaction.Compactor
import swaydb.core.level.compaction.throttle.ThrottleState
import swaydb.core.level.zero.LevelZero
Expand Down Expand Up @@ -128,7 +128,7 @@ private[core] object CoreShutdown extends LazyLogging {
actor.terminateAndRecover(retryOnBusyDelay) flatMap {
_ =>
logger.info(s"Terminated ByteBufferCleanerActor. Awaiting shutdown response.")
actor ask BufferCleaner.Command.IsTerminatedAndCleaned[Unit]
actor ask ByteBufferSweeper.Command.IsTerminatedAndCleaned[Unit]
} flatMap {
isShut =>
if (isShut)
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -32,7 +32,7 @@ import com.typesafe.scalalogging.LazyLogging
import swaydb.IO
import swaydb.IO.ExceptionHandler

private[core] object ByteBufferCleaners extends LazyLogging {
private[core] object ByteBufferCleaner extends LazyLogging {

object Cleaner {
def apply(handle: MethodHandle): Cleaner =
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -31,7 +31,7 @@ import com.typesafe.scalalogging.LazyLogging
import swaydb.Error.IO.ExceptionHandler
import swaydb._
import swaydb.core.cache.{Cache, CacheNoIO}
import swaydb.core.io.file.ByteBufferCleaners.Cleaner
import swaydb.core.io.file.ByteBufferCleaner.Cleaner
import swaydb.core.util.Counter
import swaydb.core.util.FiniteDurations._
import swaydb.data.config.ActorConfig.QueueOrder
Expand All @@ -41,7 +41,7 @@ import scala.collection.mutable
import scala.concurrent.duration._


private[core] object BufferCleaner extends LazyLogging {
private[core] object ByteBufferSweeper extends LazyLogging {

type ByteBufferSweeperActor = CacheNoIO[Unit, ActorRef[Command, State]]

Expand Down Expand Up @@ -174,7 +174,7 @@ private[core] object BufferCleaner extends LazyLogging {
case Some(cleaner) =>
IO {
cleaner.clean(buffer)
BufferCleaner.recordCleanSuccessful(path, state.pendingClean)
ByteBufferSweeper.recordCleanSuccessful(path, state.pendingClean)
state
} onLeftSideEffect {
error =>
Expand All @@ -185,10 +185,10 @@ private[core] object BufferCleaner extends LazyLogging {
}

case None =>
ByteBufferCleaners.initialiseCleaner(buffer, path) transform {
ByteBufferCleaner.initialiseCleaner(buffer, path) transform {
cleaner =>
state.cleaner = Some(cleaner)
BufferCleaner.recordCleanSuccessful(path, state.pendingClean)
ByteBufferSweeper.recordCleanSuccessful(path, state.pendingClean)
state
}
}
Expand All @@ -205,9 +205,9 @@ private[core] object BufferCleaner extends LazyLogging {
self: Actor[Command, State],
messageReschedule: FiniteDuration)(implicit scheduler: Scheduler): Unit =
if (isOverdue || command.isOverdue || messageReschedule.fromNow.isOverdue()) {
BufferCleaner.initCleanerAndPerformClean(self.state, command.buffer, command.filePath)
ByteBufferSweeper.initCleanerAndPerformClean(self.state, command.buffer, command.filePath)
} else {
BufferCleaner.recordCleanRequest(command, self.state.pendingClean)
ByteBufferSweeper.recordCleanRequest(command, self.state.pendingClean)
self.send(command.copy(isOverdue = true), messageReschedule)
}

Expand Down Expand Up @@ -290,15 +290,15 @@ private[core] object BufferCleaner extends LazyLogging {
messageReschedule: FiniteDuration)(implicit scheduler: Scheduler) =
command match {
case command: Command.Clean =>
BufferCleaner.performClean(
ByteBufferSweeper.performClean(
isOverdue = self.isTerminated,
command = command,
self = self,
messageReschedule = messageReschedule
)

case command: Command.DeleteCommand =>
BufferCleaner.performDelete(
ByteBufferSweeper.performDelete(
command = command,
self = self,
maxDeleteRetries = maxDeleteRetries,
Expand All @@ -312,7 +312,7 @@ private[core] object BufferCleaner extends LazyLogging {
command.replyTo send self.state.pendingClean.isEmpty

case command: Command.IsTerminatedAndCleaned[_] =>
BufferCleaner.performIsTerminatedAndCleaned(command, self)
ByteBufferSweeper.performIsTerminatedAndCleaned(command, self)
}

/**
Expand Down
4 changes: 2 additions & 2 deletions core/src/main/scala/swaydb/core/io/file/DBFile.scala
Original file line number Diff line number Diff line change
Expand Up @@ -30,7 +30,7 @@ import com.typesafe.scalalogging.LazyLogging
import swaydb.Error.IO.ExceptionHandler
import swaydb.core.actor.{FileSweeper, FileSweeperItem}
import swaydb.core.cache.Cache
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.data.Reserve
import swaydb.data.config.IOStrategy
import swaydb.data.slice.Slice
Expand Down Expand Up @@ -316,7 +316,7 @@ class DBFile(val path: Path,
//If the file is already closed, then delete it from disk.
//memory files are never closed so the first statement will always be executed for memory files.
if (deleteOnClean)
bufferCleaner.value(()) send BufferCleaner.Command.DeleteFile(path)
bufferCleaner.value(()) send ByteBufferSweeper.Command.DeleteFile(path)
else
fileCache.get().map(_.delete()) getOrElse Effect.deleteIfExists(path)

Expand Down
6 changes: 3 additions & 3 deletions core/src/main/scala/swaydb/core/io/file/MMAPFile.scala
Original file line number Diff line number Diff line change
Expand Up @@ -32,7 +32,7 @@ import java.util.concurrent.atomic.AtomicBoolean

import com.typesafe.scalalogging.LazyLogging
import swaydb.IO
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.data.Reserve
import swaydb.data.slice.Slice

Expand Down Expand Up @@ -144,7 +144,7 @@ private[file] class MMAPFile(val path: Path,
//the resulting NullPointerException will re-route request to the new Segment.
//TO-DO: Use Option here instead. Test using Option does not have read performance impact.
buffer = null
cleaner.actor send BufferCleaner.Command.Clean(swapBuffer, path)
cleaner.actor send ByteBufferSweeper.Command.Clean(swapBuffer, path)
}

override def append(slice: Iterable[Slice[Byte]]): Unit =
Expand Down Expand Up @@ -210,7 +210,7 @@ private[file] class MMAPFile(val path: Path,
watchNullPointer {
close()
if (deleteOnClean)
cleaner.actor send BufferCleaner.Command.DeleteFile(path)
cleaner.actor send ByteBufferSweeper.Command.DeleteFile(path)
else
Effect.delete(path)
}
Expand Down
2 changes: 1 addition & 1 deletion core/src/main/scala/swaydb/core/level/Level.scala
Original file line number Diff line number Diff line change
Expand Up @@ -33,7 +33,7 @@ import swaydb.IO._
import swaydb.core.actor.{FileSweeper, MemorySweeper}
import swaydb.core.data.{KeyValue, _}
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.Effect._
import swaydb.core.io.file.{BlockCache, Effect}
import swaydb.core.level.seek._
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -32,7 +32,7 @@ import swaydb.IO
import swaydb.IO._
import swaydb.core.actor.{FileSweeper, MemorySweeper}
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.Effect
import swaydb.core.level.AppendixSkipListMerger
import swaydb.core.map.serializer.MapEntryWriter
Expand Down
2 changes: 1 addition & 1 deletion core/src/main/scala/swaydb/core/level/zero/LevelZero.scala
Original file line number Diff line number Diff line change
Expand Up @@ -34,7 +34,7 @@ import swaydb.core.data.KeyValue.{Put, PutOption}
import swaydb.core.data.Value.FromValue
import swaydb.core.data._
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.Effect
import swaydb.core.level.seek._
import swaydb.core.level.{LevelRef, LevelSeek, NextLevel}
Expand Down
4 changes: 2 additions & 2 deletions core/src/main/scala/swaydb/core/map/Map.scala
Original file line number Diff line number Diff line change
Expand Up @@ -31,8 +31,8 @@ import com.typesafe.scalalogging.LazyLogging
import swaydb.IO
import swaydb.core.actor.FileSweeper
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.map.serializer.{MapEntryReader, MapEntryWriter}
import swaydb.core.util.IDGenerator
import swaydb.core.util.skiplist.{SkipList, SkipListBase}
Expand Down
2 changes: 1 addition & 1 deletion core/src/main/scala/swaydb/core/map/Maps.scala
Original file line number Diff line number Diff line change
Expand Up @@ -35,7 +35,7 @@ import swaydb.IO._
import swaydb.core.actor.FileSweeper
import swaydb.core.brake.BrakePedal
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.Effect
import swaydb.core.io.file.Effect._
import swaydb.core.map.serializer.{MapEntryReader, MapEntryWriter}
Expand Down
6 changes: 3 additions & 3 deletions core/src/main/scala/swaydb/core/map/PersistentMap.scala
Original file line number Diff line number Diff line change
Expand Up @@ -33,9 +33,9 @@ import swaydb.IO
import swaydb.IO._
import swaydb.core.actor.FileSweeper
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.Effect._
import swaydb.core.io.file.{BufferCleaner, DBFile, Effect}
import swaydb.core.io.file.{ByteBufferSweeper, DBFile, Effect}
import swaydb.core.map.serializer.{MapCodec, MapEntryReader, MapEntryWriter}
import swaydb.core.util.Extension
import swaydb.core.util.skiplist.{SkipList, SkipListConcurrent}
Expand Down Expand Up @@ -399,7 +399,7 @@ protected case class PersistentMap[OK, OV, K <: OK, V <: OV](path: Path,
//instead invoke close (which will also call ByteBufferCleaner for closing)
// and then submit delete to ByteBufferCleaner actor.
currentFile.close()
bufferCleaner.actor send BufferCleaner.Command.DeleteFolder(path, currentFile.path)
bufferCleaner.actor send ByteBufferSweeper.Command.DeleteFolder(path, currentFile.path)
} else {
//else delete immediately.
currentFile.delete()
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -26,8 +26,8 @@ package swaydb.core.map.serializer

import swaydb.core.actor.{FileSweeper, MemorySweeper}
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, BufferCleaner}
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, ByteBufferSweeper}
import swaydb.core.map.MapEntry
import swaydb.core.segment.{Segment, SegmentIO, SegmentSerialiser}
import swaydb.data.config.MMAP
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -32,8 +32,8 @@ import swaydb.IO
import swaydb.core.actor.FileSweeper
import swaydb.core.data.Time
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.map.serializer.{MapEntryReader, MapEntryWriter}
import swaydb.core.map.{Map, MapEntry, PersistentMap, SkipListMerger}
import swaydb.core.util.skiplist.SkipListConcurrent
Expand Down
4 changes: 2 additions & 2 deletions core/src/main/scala/swaydb/core/map/timer/Timer.scala
Original file line number Diff line number Diff line change
Expand Up @@ -29,8 +29,8 @@ import java.nio.file.Path
import swaydb.IO
import swaydb.core.data.Time
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.map.MapEntry
import swaydb.core.map.serializer.{MapEntryReader, MapEntryWriter}
import swaydb.data.config.MMAP
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -32,7 +32,7 @@ import swaydb.core.actor.{FileSweeper, MemorySweeper}
import swaydb.core.cache.{Cache, CacheNoIO}
import swaydb.core.data._
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, DBFile, Effect}
import swaydb.core.level.PathsDistributor
import swaydb.core.segment.format.a.block.binarysearch.BinarySearchIndexBlock
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -32,7 +32,7 @@ import swaydb.IO
import swaydb.core.actor.{FileSweeper, MemorySweeper}
import swaydb.core.data.{KeyValue, Persistent, PersistentOption}
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, DBFile}
import swaydb.core.level.PathsDistributor
import swaydb.core.segment.format.a.block.binarysearch.BinarySearchIndexBlock
Expand Down
2 changes: 1 addition & 1 deletion core/src/main/scala/swaydb/core/segment/Segment.scala
Original file line number Diff line number Diff line change
Expand Up @@ -33,7 +33,7 @@ import swaydb.IO._
import swaydb.core.actor.{FileSweeper, FileSweeperItem, MemorySweeper}
import swaydb.core.data._
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, DBFile, Effect}
import swaydb.core.level.PathsDistributor
import swaydb.core.map.Map
Expand Down
Original file line number Diff line number Diff line change
Expand Up @@ -30,7 +30,7 @@ import java.util.concurrent.TimeUnit

import swaydb.core.actor.{FileSweeper, MemorySweeper}
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, Effect}
import swaydb.core.util.Options._
import swaydb.core.util.{BlockCacheFileIDGenerator, Bytes, Extension, MinMax}
Expand Down
6 changes: 3 additions & 3 deletions core/src/test/scala/swaydb/core/CommonAssertions.scala
Original file line number Diff line number Diff line change
Expand Up @@ -38,8 +38,8 @@ import swaydb.core.actor.MemorySweeper
import swaydb.core.data.Memory.PendingApply
import swaydb.core.data.Value.FromValue
import swaydb.core.data.{KeyValue, Memory, Value, _}
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.{BufferCleaner, Effect}
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.{ByteBufferSweeper, Effect}
import swaydb.core.io.reader.Reader
import swaydb.core.level.zero.{LevelZero, LevelZeroSkipListMerger}
import swaydb.core.level.{Level, LevelRef, NextLevel}
Expand Down Expand Up @@ -1775,7 +1775,7 @@ object CommonAssertions {
def ensureClose(): Unit = {
maps.close.value
maps.bufferCleaner.actor.receiveAllBlocking(Int.MaxValue).get
(maps.bufferCleaner.actor ask BufferCleaner.Command.IsTerminatedAndCleaned[Unit]).await(10.seconds)
(maps.bufferCleaner.actor ask ByteBufferSweeper.Command.IsTerminatedAndCleaned[Unit]).await(10.seconds)
}
}
}
Expand Down
2 changes: 1 addition & 1 deletion core/src/test/scala/swaydb/core/TestBase.scala
Original file line number Diff line number Diff line change
Expand Up @@ -40,7 +40,7 @@ import swaydb.core.TestData._
import swaydb.core.TestSweeper.{fileSweeper, _}
import swaydb.core.actor.{FileSweeper, MemorySweeper}
import swaydb.core.data.{Memory, MemoryOption, Time}
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, DBFile, Effect}
import swaydb.core.io.reader.FileReader
import swaydb.core.level.compaction._
Expand Down
4 changes: 2 additions & 2 deletions core/src/test/scala/swaydb/core/TestData.scala
Original file line number Diff line number Diff line change
Expand Up @@ -39,8 +39,8 @@ import swaydb.core.cache.Cache
import swaydb.core.data.Value.{FromValue, FromValueOption, RangeValue}
import swaydb.core.data.{KeyValue, _}
import swaydb.core.function.FunctionStore
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, BufferCleaner}
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, ByteBufferSweeper}
import swaydb.core.level.seek._
import swaydb.core.level.zero.LevelZero
import swaydb.core.level.{Level, NextLevel}
Expand Down
6 changes: 3 additions & 3 deletions core/src/test/scala/swaydb/core/TestSweeper.scala
Original file line number Diff line number Diff line change
Expand Up @@ -26,8 +26,8 @@ package swaydb.core

import swaydb.core.CommonAssertions._
import swaydb.core.actor.{FileSweeper, MemorySweeper}
import swaydb.core.io.file.BufferCleaner.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, BufferCleaner}
import swaydb.core.io.file.ByteBufferSweeper.ByteBufferSweeperActor
import swaydb.core.io.file.{BlockCache, ByteBufferSweeper}
import swaydb.data.config.{ActorConfig, MemoryCache}
import swaydb.data.util.StorageUnits._

Expand Down Expand Up @@ -65,5 +65,5 @@ private[swaydb] object TestSweeper {
val fileSweeper: FileSweeper.Enabled =
FileSweeper(50, ActorConfig.Basic("Basic test 3", level0PushDownPool))

val bufferCleaner: ByteBufferSweeperActor = BufferCleaner()(TestData.scheduler)
val bufferCleaner: ByteBufferSweeperActor = ByteBufferSweeper()(TestData.scheduler)
}
Loading

0 comments on commit 8e3fccb

Please sign in to comment.