Module Contents alltypes
      Module Contents class BTreeMap<K, V> : Verifiable, Closeable, Serializable, ConcurrencyAware, ConcurrentNavigableMap<K, V>, ConcurrentNavigableMapExtra<K, V>
        Module Contents BTreeMap(keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>, rootRecidRecid: Long, store: Store, valueInline: Boolean, maxNodeSize: Int, comparator: Comparator<K>, isThreadSafe: Boolean, counterRecid: Long, hasValues: Boolean, modificationListeners: Array<MapModificationListener<K, V>>?)
        abstract class BTreeBoundIterator<K, V>
          Module Contents BTreeBoundIterator(m: BTreeMap<K, V>, lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean)
          protected fun advance(): Unit
          protected fun checkHiBound(): Unit
          protected var currentLeaf: Node?
          protected var currentPos: Int
          fun hasNext(): Boolean
          val hi: K?
          protected val hiC: Int
          val hiInclusive: Boolean
          protected var lastReturnedKey: K?
          val lo: K?
          val loInclusive: Boolean
          val m: BTreeMap<K, V>
          fun remove(): Unit
        abstract class BTreeIterator<K, V>
          Module Contents BTreeIterator(m: BTreeMap<K, V>)
          protected fun advance(): Unit
          protected var currentLeaf: Node?
          protected var currentPos: Int
          fun hasNext(): Boolean
          protected var lastReturnedKey: K?
          val m: BTreeMap<K, V>
          fun remove(): Unit
        abstract class DescendingBoundIterator<K, V>
          Module Contents DescendingBoundIterator(m: BTreeMap<K, V>, lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean)
          protected fun advance(): Unit
          protected fun advanceNode(): Unit
          protected fun checkLoBound(): Unit
          protected var currentLeaf: Node?
          protected var currentPos: Int
          protected val descLeafIter: Iterator<Node>
          fun hasNext(): Boolean
          val hi: K?
          val hiInclusive: Boolean
          protected var lastReturnedKey: K?
          val lo: K?
          protected val loC: Int
          val loInclusive: Boolean
          val m: BTreeMap<K, V>
          fun remove(): Unit
        abstract class DescendingIterator<K, V>
          Module Contents DescendingIterator(m: BTreeMap<K, V>)
          protected fun advance(): Unit
          protected fun advanceNode(): Unit
          protected var currentLeaf: Node?
          protected var currentPos: Int
          protected val descLeafIter: Iterator<Node>
          fun hasNext(): Boolean
          protected var lastReturnedKey: K?
          val m: BTreeMap<K, V>
          fun remove(): Unit
        fun assertCurrentThreadUnlocked(): Unit
        protected fun btreeEntry(key: K, valueOrig: V?): MutableEntry<K, V?>
        fun ceilingEntry(key: K?): MutableEntry<K, V>?
        fun ceilingKey(key: K?): K?
        fun checkThreadSafe(): Unit
        fun clear(): Unit
        fun close(): Unit
        fun comparator(): Comparator<in K>?
        val comparator: Comparator<K>
        fun containsKey(key: K): Boolean
        fun containsValue(value: V): Boolean
        val counterRecid: Long
        fun descendingEntryIterator(): MutableIterator<MutableEntry<K, V?>>
        fun descendingEntryIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<MutableEntry<K, V?>>
        fun descendingKeyIterator(): MutableIterator<K>
        fun descendingKeyIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<K>
        fun descendingKeySet(): NavigableSet<K>?
        fun descendingLeafIterator(hi: K?): Iterator<Node>
        fun descendingMap(): ConcurrentNavigableMap<K, V>?
        fun descendingValueIterator(): MutableIterator<V?>
        fun descendingValueIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<V?>
        val entries: MutableSet<MutableEntry<K, V?>>
        fun entryIterator(): MutableIterator<MutableEntry<K, V?>>
        fun entryIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<MutableEntry<K, V?>>
        fun equals(other: Any?): Boolean
        fun findHigher(key: K?, inclusive: Boolean): MutableEntry<K, V>?
        fun findHigherKey(key: K?, inclusive: Boolean): K?
        fun findLower(key: K?, inclusive: Boolean): MutableEntry<K, V>?
        fun findLowerKey(key: K?, inclusive: Boolean): K?
        fun firstEntry(): MutableEntry<K, V?>?
        fun firstKey(): K
        fun firstKey2(): K?
        fun floorEntry(key: K?): MutableEntry<K, V>?
        fun floorKey(key: K): K?
        fun forEach(action: BiConsumer<in K, in V>?): Unit
        fun forEachKey(procedure: (K) -> Unit): Unit
        fun forEachValue(procedure: (V) -> Unit): Unit
        operator fun get(key: K?): V?
        val hasValues: Boolean
        fun hashCode(): Int
        fun headMap(toKey: K?, inclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun headMap(toKey: K): ConcurrentNavigableMap<K, V>
        fun higherEntry(key: K?): MutableEntry<K, V>?
        fun higherKey(key: K?): K?
        fun isClosed(): Boolean
        fun isEmpty(): Boolean
        val isThreadSafe: Boolean
        fun keyIterator(): MutableIterator<K>
        fun keyIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<K>
        val keySerializer: GroupSerializer<K>
        val keys: NavigableSet<K?>
        fun lastEntry(): MutableEntry<K, V?>?
        fun lastKey(): K
        fun lastKey2(): K?
        protected val leftEdges: <ERROR CLASS>
        protected fun listenerNotify(key: K, oldValue: V?, newValue: V?, triggered: Boolean): Unit
        fun lock(nodeRecid: Long): Unit
        protected val locks: ConcurrentHashMap<Long, Long>
        fun lowerEntry(key: K?): MutableEntry<K, V>?
        fun lowerKey(key: K): K?
        fun <K, V> make(keySerializer: GroupSerializer<K> = Serializer.ELSA as GroupSerializer<K>, valueSerializer: GroupSerializer<V> = Serializer.ELSA as GroupSerializer<V>, store: Store = StoreTrivial(), valueInline: Boolean = true, rootRecidRecid: Long = putEmptyRoot(store, keySerializer, if(valueInline) valueSerializer else Serializer.RECID), maxNodeSize: Int = CC.BTREEMAP_MAX_NODE_SIZE, comparator: Comparator<K> = keySerializer, isThreadSafe: Boolean = true, counterRecid: Long = 0L, hasValues: Boolean = true, modificationListeners: Array<MapModificationListener<K, V>>? = null): BTreeMap<K, V>
        val maxNodeSize: Int
        fun navigableKeySet(): NavigableSet<K?>
        protected val nodeSerializer: NodeSerializer
        fun pollFirstEntry(): MutableEntry<K, V?>?
        fun pollLastEntry(): MutableEntry<K, V?>?
        fun prefixSubMap(prefix: K): ConcurrentNavigableMap<K, V>
        fun prefixSubMap(prefix: K, inclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun printStructure(out: PrintStream): Unit
        fun put(key: K?, value: V?): V?
        protected fun put2(key: K, value: V, onlyIfAbsent: Boolean): V?
        fun putAll(from: Map<out K?, V?>): Unit
        fun putIfAbsent(key: K?, value: V?): V?
        fun putIfAbsentBoolean(key: K?, value: V?): Boolean
        fun remove(key: K?): V?
        fun remove(key: Any?, value: Any?): Boolean
        protected fun removeOrReplace(key: K, expectedOldValue: V?, replaceWithValue: V?): V?
        fun replace(key: K?, oldValue: V?, newValue: V?): Boolean
        fun replace(key: K?, value: V?): V?
        protected val rootRecid: Long
        val rootRecidRecid: Long
        val size: Int
        fun sizeLong(): Long
        val store: Store
        fun subMap(fromKey: K?, fromInclusive: Boolean, toKey: K?, toInclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun subMap(fromKey: K, toKey: K): ConcurrentNavigableMap<K, V>
        fun tailMap(fromKey: K?, inclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun tailMap(fromKey: K): ConcurrentNavigableMap<K, V>
        fun unlock(nodeRecid: Long): Unit
        fun unlockAllCurrentThread(): Unit
        protected fun valueExpand(v: Any?): V?
        val valueInline: Boolean
        fun valueIterator(): MutableIterator<V?>
        fun valueIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<V?>
        protected val valueNodeSerializer: GroupSerializer<Any>
        val valueSerializer: GroupSerializer<V>
        val values: MutableCollection<V?>
        fun verify(): Unit
      interface ConcurrencyAware
        Module Contents open fun checkThreadSafe(): Unit
        abstract val isThreadSafe: Boolean
      interface ConcurrentNavigableMapExtra<K, V> : ConcurrentNavigableMap<K, V>, MapExtra<K, V>, ConcurrentNavigableMap2<K, V>
        Module Contents abstract fun descendingEntryIterator(): MutableIterator<MutableEntry<K, V?>>
        abstract fun descendingEntryIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<MutableEntry<K, V?>>
        abstract fun descendingKeyIterator(): MutableIterator<K>
        abstract fun descendingKeyIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<K>
        abstract fun descendingValueIterator(): MutableIterator<V?>
        abstract fun descendingValueIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<V?>
        abstract fun entryIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<MutableEntry<K, V?>>
        abstract fun findHigher(key: K?, inclusive: Boolean): MutableEntry<K, V>?
        abstract fun findHigherKey(key: K?, inclusive: Boolean): K?
        abstract fun findLower(key: K?, inclusive: Boolean): MutableEntry<K, V>?
        abstract fun findLowerKey(key: K?, inclusive: Boolean): K?
        abstract val hasValues: Boolean
        abstract fun keyIterator(): MutableIterator<K>
        abstract fun keyIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<K?>
        abstract fun valueIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<V?>
      open class DB : Closeable, ConcurrencyAware
        Module Contents DB(store: Store, storeOpened: Boolean, isThreadSafe: Boolean = true, classLoader: ClassLoader = Thread.currentThread().contextClassLoader, shutdownHook: Int = 0)
        class AtomicBooleanMaker : Maker<Boolean>
          Module Contents AtomicBooleanMaker(db: DB, name: String, value: Boolean = false)
          protected fun create2(catalog: SortedMap<String, String>): Boolean
          protected val db: DB
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): Boolean
          protected val type: String
          protected val value: Boolean
        class AtomicIntegerMaker : Maker<Integer>
          Module Contents AtomicIntegerMaker(db: DB, name: String, value: Int = 0)
          protected fun create2(catalog: SortedMap<String, String>): Integer
          protected val db: DB
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): Integer
          protected val type: String
          protected val value: Int
        class AtomicLongMaker : Maker<Long>
          Module Contents AtomicLongMaker(db: DB, name: String, value: Long = 0)
          protected fun create2(catalog: SortedMap<String, String>): Long
          protected val db: DB
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): Long
          protected val type: String
          protected val value: Long
        class AtomicStringMaker : Maker<String>
          Module Contents AtomicStringMaker(db: DB, name: String, value: String? = null)
          protected fun create2(catalog: SortedMap<String, String>): String
          protected val db: DB
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): String
          protected val type: String
          protected val value: String?
        class AtomicVarMaker<E> : Maker<Var<E>>
          Module Contents AtomicVarMaker(db: DB, name: String, serializer: Serializer<E> = db.defaultSerializer as Serializer<E>, value: E? = null)
          protected fun create2(catalog: SortedMap<String, String>): Var<E>
          protected val db: DB
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): Var<E>
          protected val serializer: Serializer<E>
          protected val type: String
          protected val value: E?
        protected data class CatVal
          Module Contents CatVal(msg: (String) -> String?, required: Boolean = true)
          val msg: (String) -> String?
          val required: Boolean
        class HashMapMaker<K, V> : Maker<HTreeMap<K, V>>
          Module Contents HashMapMaker(db: DB, name: String, hasValues: Boolean = true, _storeFactory: (Int) -> Store = {i-> db.store})
          protected val _storeFactory: (Int) -> Store
          fun counterEnable(): HashMapMaker<K, V>
          fun create(): HTreeMap<K, V>
          protected fun create2(catalog: SortedMap<String, String>): HTreeMap<K, V>
          fun createOrOpen(): HTreeMap<K, V>
          protected val db: DB
          fun expireAfterCreate(): HashMapMaker<K, V>
          fun expireAfterCreate(ttl: Long): HashMapMaker<K, V>
          fun expireAfterCreate(ttl: Long, unit: TimeUnit): HashMapMaker<K, V>
          fun expireAfterGet(): HashMapMaker<K, V>
          fun expireAfterGet(ttl: Long): HashMapMaker<K, V>
          fun expireAfterGet(ttl: Long, unit: TimeUnit): HashMapMaker<K, V>
          fun expireAfterUpdate(): HashMapMaker<K, V>
          fun expireAfterUpdate(ttl: Long): HashMapMaker<K, V>
          fun expireAfterUpdate(ttl: Long, unit: TimeUnit): HashMapMaker<K, V>
          fun expireCompactThreshold(freeFraction: Double): HashMapMaker<K, V>
          fun expireExecutor(executor: ScheduledExecutorService?): HashMapMaker<K, V>
          fun expireExecutorPeriod(period: Long): HashMapMaker<K, V>
          fun expireMaxSize(maxSize: Long): HashMapMaker<K, V>
          fun expireOverflow(overflowMap: MutableMap<K, V?>): HashMapMaker<K, V>
          fun expireStoreSize(storeSize: Long): HashMapMaker<K, V>
          protected val hasValues: Boolean
          fun hashSeed(hashSeed: Int): HashMapMaker<K, V>
          fun <A> keySerializer(keySerializer: Serializer<A>): HashMapMaker<A, V>
          fun layout(concurrency: Int, dirSize: Int, levels: Int): HashMapMaker<K, V>
          fun modificationListener(listener: MapModificationListener<K, V>): HashMapMaker<K, V>
          protected val name: String
          fun open(): HTreeMap<K, V>
          protected fun open2(catalog: SortedMap<String, String>): HTreeMap<K, V>
          fun removeCollapsesIndexTreeDisable(): HashMapMaker<K, V>
          protected val type: String
          fun valueInline(): HashMapMaker<K, V>
          fun valueLoader(valueLoader: (K) -> V): HashMapMaker<K, V>
          fun <A> valueSerializer(valueSerializer: Serializer<A>): HashMapMaker<K, A>
          protected fun verify(): Unit
        class HashSetMaker<E> : Maker<KeySet<E>>
          Module Contents HashSetMaker(db: DB, name: String, _storeFactory: (Int) -> Store = {i-> db.store})
          protected val _storeFactory: (Int) -> Store
          fun counterEnable(): HashSetMaker<E>
          protected fun create2(catalog: SortedMap<String, String>): KeySet<E>
          protected val db: DB
          fun expireAfterCreate(): HashSetMaker<E>
          fun expireAfterCreate(ttl: Long): HashSetMaker<E>
          fun expireAfterCreate(ttl: Long, unit: TimeUnit): HashSetMaker<E>
          fun expireAfterGet(): HashSetMaker<E>
          fun expireAfterGet(ttl: Long): HashSetMaker<E>
          fun expireAfterGet(ttl: Long, unit: TimeUnit): HashSetMaker<E>
          fun expireCompactThreshold(freeFraction: Double): HashSetMaker<E>
          fun expireExecutor(executor: ScheduledExecutorService?): HashSetMaker<E>
          fun expireExecutorPeriod(period: Long): HashSetMaker<E>
          fun expireMaxSize(maxSize: Long): HashSetMaker<E>
          fun expireStoreSize(storeSize: Long): HashSetMaker<E>
          fun hashSeed(hashSeed: Int): HashSetMaker<E>
          fun layout(concurrency: Int, dirSize: Int, levels: Int): HashSetMaker<E>
          protected val maker: HashMapMaker<E, Any?>
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): KeySet<E>
          fun removeCollapsesIndexTreeDisable(): HashSetMaker<E>
          fun <A> serializer(serializer: Serializer<A>): HashSetMaker<A>
          protected val type: String
          protected fun verify(): Unit
        class IndexTreeListMaker<E> : Maker<IndexTreeList<E>>
          Module Contents IndexTreeListMaker(db: DB, name: String, serializer: Serializer<E>)
          protected fun create2(catalog: SortedMap<String, String>): IndexTreeList<E>
          protected val db: DB
          fun layout(dirSize: Int, levels: Int): IndexTreeListMaker<E>
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): IndexTreeList<E>
          fun removeCollapsesIndexTreeDisable(): IndexTreeListMaker<E>
          protected val serializer: Serializer<E>
          protected val type: String
        class IndexTreeLongLongMapMaker : Maker<IndexTreeLongLongMap>
          Module Contents IndexTreeLongLongMapMaker(db: DB, name: String)
          protected fun create2(catalog: SortedMap<String, String>): IndexTreeLongLongMap
          protected val db: DB
          fun layout(dirSize: Int, levels: Int): IndexTreeLongLongMapMaker
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): IndexTreeLongLongMap
          fun removeCollapsesIndexTreeDisable(): IndexTreeLongLongMapMaker
          protected val type: String
        object Keys
          Module Contents val concShift: String
          val counterRecid: String
          val counterRecids: String
          val dirShift: String
          val expireCreateQueue: String
          val expireCreateTTL: String
          val expireGetQueue: String
          val expireGetTTL: String
          val expireUpdateQueue: String
          val expireUpdateTTL: String
          val hashSeed: String
          val keySerializer: String
          val levels: String
          val maxNodeSize: String
          val recid: String
          val removeCollapsesIndexTree: String
          val rootRecid: String
          val rootRecidRecid: String
          val rootRecids: String
          val segmentRecids: String
          val serializer: String
          val size: String
          val type: String
          val valueInline: String
          val valueSerializer: String
        abstract class Maker<E>
          Module Contents Maker()
          open fun create(): E
          protected abstract fun create2(catalog: SortedMap<String, String>): E
          open fun createOrOpen(): E
          protected abstract val db: DB
          open fun make(): E
          protected fun make2(create: Boolean?): E
          open fun makeOrGet(): E
          protected abstract val name: String
          open fun open(): E
          protected abstract fun open2(catalog: SortedMap<String, String>): E
          protected abstract val type: String
          protected open fun verify(): Unit
        protected val NAMED_SERIALIZATION_HEADER: Int
        protected val NAME_CATALOG_SERIALIZER: Serializer<SortedMap<String, String>>
        class TreeMapMaker<K, V> : Maker<BTreeMap<K, V>>
          Module Contents TreeMapMaker(db: DB, name: String, hasValues: Boolean = true)
          fun counterEnable(): TreeMapMaker<K, V>
          fun create(): BTreeMap<K, V>
          protected fun create2(catalog: SortedMap<String, String>): BTreeMap<K, V>
          fun createFrom(iterator: Iterator<<ERROR CLASS><K, V>>): BTreeMap<K, V>
          fun createFromSink(): TreeMapSink<K, V>
          fun createOrOpen(): BTreeMap<K, V>
          protected val db: DB
          protected val hasValues: Boolean
          fun <A> keySerializer(keySerializer: GroupSerializer<A>): TreeMapMaker<A, V>
          fun maxNodeSize(size: Int): TreeMapMaker<K, V>
          fun modificationListener(listener: MapModificationListener<K, V>): TreeMapMaker<K, V>
          protected val name: String
          fun open(): BTreeMap<K, V>
          protected fun open2(catalog: SortedMap<String, String>): BTreeMap<K, V>
          protected val type: String
          fun <A> valueSerializer(valueSerializer: GroupSerializer<A>): TreeMapMaker<K, A>
          fun valuesOutsideNodesEnable(): TreeMapMaker<K, V>
        abstract class TreeMapSink<K, V> : Sink<<ERROR CLASS><K, V>, BTreeMap<K, V>>
          Module Contents TreeMapSink()
          fun put(key: K, value: V): Unit
          fun putAll(map: SortedMap<K, V>): Unit
        class TreeSetMaker<E> : Maker<NavigableSet<E>>
          Module Contents TreeSetMaker(db: DB, name: String)
          fun counterEnable(): TreeSetMaker<E>
          protected fun create2(catalog: SortedMap<String, String>): NavigableSet<E>
          protected val db: DB
          protected val maker: TreeMapMaker<E, Any?>
          fun maxNodeSize(size: Int): TreeSetMaker<E>
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): NavigableSet<E>
          fun <A> serializer(serializer: GroupSerializer<A>): TreeSetMaker<A>
          protected val type: String
          protected fun verify(): Unit
        protected fun addShutdownHook(ref: Any): Unit
        fun atomicBoolean(name: String): AtomicBooleanMaker
        fun atomicBoolean(name: String, value: Boolean): AtomicBooleanMaker
        fun atomicInteger(name: String): AtomicIntegerMaker
        fun atomicInteger(name: String, value: Int): AtomicIntegerMaker
        fun atomicLong(name: String): AtomicLongMaker
        fun atomicLong(name: String, value: Long): AtomicLongMaker
        fun atomicString(name: String): AtomicStringMaker
        fun atomicString(name: String, value: String?): AtomicStringMaker
        fun atomicVar(name: String): AtomicVarMaker<Any?>
        fun <E> atomicVar(name: String, serializer: Serializer<E>): AtomicVarMaker<E>
        fun <E> atomicVar(name: String, serializer: Serializer<E>, value: E?): AtomicVarMaker<E>
        protected fun checkName(name: String): Unit
        protected fun checkNotClosed(): Unit
        open fun checkThreadSafe(): Unit
        protected val classInfoSerializer: Serializer<Array<<ERROR CLASS>>>
        val classLoader: ClassLoader
        open fun close(): Unit
        fun commit(): Unit
        val defaultSerializer: GroupSerializerObjectArray<Any?>
        fun defaultSerializerRegisterClass(clazz: Class<*>): Unit
        protected val executors: MutableSet<ExecutorService>
        fun exists(name: String): Boolean
        fun <E> get(name: String): E
        fun getAll(): Map<String, Any?>
        fun getAllNames(): Iterable<String>
        fun getNameForObject(e: Any): String?
        fun getStore(): Store
        fun hashMap(name: String): HashMapMaker<*, *>
        fun <K, V> hashMap(name: String, keySerializer: Serializer<K>, valueSerializer: Serializer<V>): HashMapMaker<K, V>
        fun hashSet(name: String): HashSetMaker<*>
        fun <E> hashSet(name: String, serializer: Serializer<E>): HashSetMaker<E>
        fun <E> indexTreeList(name: String, serializer: Serializer<E>): IndexTreeListMaker<E>
        fun indexTreeList(name: String): IndexTreeListMaker<Any?>
        fun isClosed(): Boolean
        open val isThreadSafe: Boolean
        protected val lock: ReentrantReadWriteLock?
        protected fun nameCatalogGet(name: String): String?
        fun <E> nameCatalogGetClass(nameCatalog: SortedMap<String, String>, key: String): E?
        fun nameCatalogLoad(): SortedMap<String, String>
        protected fun nameCatalogLoadLocked(): SortedMap<String, String>
        fun nameCatalogParamsFor(name: String): Map<String, String>
        fun nameCatalogPutClass(nameCatalog: SortedMap<String, String>, key: String, obj: Any): Unit
        fun nameCatalogSave(nameCatalog: SortedMap<String, String>): Unit
        protected fun nameCatalogSaveLocked(nameCatalog: SortedMap<String, String>): Unit
        fun nameCatalogVerifyGetMessages(): Iterable<String>
        protected var namesInstanciated: <ERROR CLASS><String, Any?>
        fun rollback(): Unit
        val shutdownHook: Int
        protected val storeOpened: Boolean
        fun treeMap(name: String): TreeMapMaker<*, *>
        fun <K, V> treeMap(name: String, keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>): TreeMapMaker<K, V>
        fun treeSet(name: String): TreeSetMaker<*>
        fun <E> treeSet(name: String, serializer: GroupSerializer<E>): TreeSetMaker<E>
      open class DBException : RuntimeException
        Module Contents DBException(message: String)
        DBException(message: String?, cause: Throwable?)
        open class DataCorruption : DBException
          Module Contents DataCorruption(msg: String)
        class FileLocked : DBException
          Module Contents FileLocked(path: Path, exception: Exception)
        class GetVoid : DBException
          Module Contents GetVoid(recid: Long)
        class Interrupted : DBException
          Module Contents Interrupted(e: InterruptedException)
        class NewMapDBFormat : DBException
          Module Contents NewMapDBFormat(message: String = "Store uses feature from newer version of MapDB, this MapDB version is old does not support new feature")
        class NotSorted : DBException
          Module Contents NotSorted()
        class OutOfMemory : VolumeIOError
          Module Contents OutOfMemory(e: Throwable)
        class PointerChecksumBroken : DataCorruption
          Module Contents PointerChecksumBroken()
        open class SerializationError : DBException
          Module Contents SerializationError(e: Throwable)
          SerializationError(msg: String)
          SerializationError(msg: String?, e: Throwable?)
        open class VolumeClosed : DBException
          Module Contents VolumeClosed(e: Throwable)
          VolumeClosed(msg: String)
          VolumeClosed(msg: String?, e: Throwable?)
        open class VolumeClosedByInterrupt : DBException
          Module Contents VolumeClosedByInterrupt(e: Throwable?)
        open class VolumeEOF : VolumeIOError
          Module Contents VolumeEOF(e: IOException)
          VolumeEOF(msg: String)
          VolumeEOF(msg: String?, e: IOException?)
        open class VolumeIOError : DBException
          Module Contents VolumeIOError(e: IOException)
          VolumeIOError(msg: String)
          VolumeIOError(msg: String?, e: Throwable?)
        class VolumeMaxSizeExceeded : DBException
          Module Contents VolumeMaxSizeExceeded(length: Long, requestedLength: Long)
        class WrongConfiguration : DBException
          Module Contents WrongConfiguration(message: String)
        class WrongFormat : DBException
          Module Contents WrongFormat(msg: String)
      object DBMaker
        Module Contents class Maker
          Module Contents Maker(_storeType: StoreType?, _customVolume: Volume? = null, _volumeExist: Boolean? = null, file: String? = null)
          fun allocateIncrement(incrementSize: Long): Maker
          fun allocateStartSize(size: Long): Maker
          protected fun assertFile(): Unit
          fun checksumHeaderBypass(): Maker
          fun checksumStoreEnable(): Maker
          fun cleanerHackEnable(): Maker
          fun closeOnJvmShutdown(): Maker
          fun closeOnJvmShutdownWeakReference(): Maker
          fun concurrencyDisable(): Maker
          fun concurrencyScale(segmentCount: Int): Maker
          fun deleteFilesAfterClose(): Maker
          fun executorEnable(): Maker
          fun fileChannelEnable(): Maker
          fun fileDeleteAfterClose(): Maker
          fun fileDeleteAfterOpen(): Maker
          fun fileLockDisable(): Maker
          fun fileLockWait(timeout: Long): Maker
          fun fileLockWait(): Maker
          fun fileMmapEnable(): Maker
          fun fileMmapEnableIfSupported(): Maker
          fun fileMmapPreclearDisable(): Maker
          fun make(): DB
          fun readOnly(): Maker
          fun transactionEnable(): Maker
        enum class StoreType
          Module Contents bytearray
          directbuffer
          fileChannel
          fileMMap
          fileRaf
          onheap
        fun fileDB(file: String): Maker
        fun fileDB(file: File): Maker
        fun heapDB(): Maker
        fun heapShardedHashMap(concurrency: Int): HashMapMaker<*, *>
        fun heapShardedHashSet(concurrency: Int): HashSetMaker<*>
        fun memoryDB(): Maker
        fun memoryDirectDB(): Maker
        fun memoryShardedHashMap(concurrency: Int): HashMapMaker<*, *>
        fun memoryShardedHashSet(concurrency: Int): HashSetMaker<*>
        fun tempFileDB(): Maker
        fun volumeDB(volume: Volume, volumeExists: Boolean): Maker
      class HTreeMap<K, V> : ConcurrentMap<K, V>, ConcurrencyAware, MapExtra<K, V>, Verifiable, Closeable
        Module Contents HTreeMap(keySerializer: Serializer<K>, valueSerializer: Serializer<V>, valueInline: Boolean, concShift: Int, dirShift: Int, levels: Int, stores: Array<Store>, indexTrees: Array<<ERROR CLASS>>, hashSeed: Int, counterRecids: LongArray?, expireCreateTTL: Long, expireUpdateTTL: Long, expireGetTTL: Long, expireMaxSize: Long, expireStoreSize: Long, expireCreateQueues: Array<QueueLong>?, expireUpdateQueues: Array<QueueLong>?, expireGetQueues: Array<QueueLong>?, expireExecutor: ScheduledExecutorService?, expireExecutorPeriod: Long, expireCompactThreshold: Double?, isThreadSafe: Boolean, valueLoader: (K) -> V?, modificationListeners: Array<MapModificationListener<K, V>>?, closeable: Closeable?, hasValues: Boolean = true)
        class KeySet<K> : AbstractSet<K>
          Module Contents KeySet(map: HTreeMap<K, Any?>)
          fun add(element: K): Boolean
          fun clear(): Unit
          fun isEmpty(): Boolean
          fun iterator(): MutableIterator<K?>
          val map: HTreeMap<K, Any?>
          fun remove(element: K): Boolean
          val size: Int
        protected val QUEUE_CREATE: Long
        protected val QUEUE_GET: Long
        protected val QUEUE_UPDATE: Long
        fun calculateCollisionSize(): <ERROR CLASS><Long, Long>
        fun checkThreadSafe(): Unit
        fun clear(): Unit
        protected fun clear(notifyListeners: Int = 1): Unit
        fun clear2(notifyListeners: Boolean = true): Unit
        fun clearWithExpire(): Unit
        fun clearWithoutNotification(): Unit
        fun close(): Unit
        val concShift: Int
        fun containsKey(key: K?): Boolean
        fun containsValue(value: V?): Boolean
        val counterRecids: LongArray?
        val dirShift: Int
        val entries: MutableSet<MutableEntry<K?, V?>>
        fun equals(other: Any?): Boolean
        val expireCompactThreshold: Double?
        val expireCreateQueues: Array<QueueLong>?
        val expireCreateTTL: Long
        fun expireEvict(): Unit
        protected fun expireEvictEntry(segment: Int, leafRecid: Long, nodeRecid: Long): Unit
        protected fun expireEvictSegment(segment: Int): Unit
        val expireExecutor: ScheduledExecutorService?
        val expireExecutorPeriod: Long
        val expireGetQueues: Array<QueueLong>?
        val expireGetTTL: Long
        protected fun expireId(nodeRecid: Long, queue: Long): Long
        val expireMaxSize: Long
        protected fun expireNodeRecidFor(expireId: Long): Long
        protected fun expireQueueFor(segment: Int, expireId: Long): QueueLong
        val expireStoreSize: Long
        val expireUpdateQueues: Array<QueueLong>?
        val expireUpdateTTL: Long
        fun forEach(action: BiConsumer<in K, in V>): Unit
        fun forEachKey(action: (K) -> Unit): Unit
        fun forEachValue(action: (V) -> Unit): Unit
        fun get(key: K?): V?
        protected fun getprotected(hash: Int, key: K, updateQueue: Boolean): V?
        val hasValues: Boolean
        protected fun hash(key: K): Int
        fun hashCode(): Int
        protected fun hashToIndex(hash: Int): Long
        protected fun hashToSegment(hash: Int): Int
        protected fun htreeEntry(key: K, valueOrig: V): MutableEntry<K?, V?>
        protected fun <E> htreeIterator(segment: Int, loadNext: (Any, Any) -> E): MutableIterator<E>
        val indexTrees: Array<<ERROR CLASS>>
        fun isClosed(): Boolean
        fun isEmpty(): Boolean
        val isForegroundEviction: Boolean
        val isThreadSafe: Boolean
        val keySerializer: Serializer<K>
        val keys: KeySet<K>
        protected fun leafGet(store: Store, leafRecid: Long): Array<Any>
        protected val leafSerializer: Serializer<Array<Any>>
        val levels: Int
        protected fun listenerNotify(key: K, oldValue: V?, newValue: V?, triggered: Boolean): Unit
        protected val locks: Array<ReadWriteLock?>
        fun <K, V> make(keySerializer: Serializer<K> = Serializer.ELSA as Serializer<K>, valueSerializer: Serializer<V> = Serializer.ELSA as Serializer<V>, valueInline: Boolean = false, concShift: Int = CC.HTREEMAP_CONC_SHIFT, dirShift: Int = CC.HTREEMAP_DIR_SHIFT, levels: Int = CC.HTREEMAP_LEVELS, stores: Array<Store> = Array(1.shl(concShift), {StoreTrivial()}), indexTrees: Array<<ERROR CLASS>> = Array(1.shl(concShift), { i->IndexTreeLongLongMap.make(stores[i], levels=levels, dirShift = dirShift)}), hashSeed: Int = SecureRandom().nextInt(), counterRecids: LongArray? = null, expireCreateTTL: Long = 0L, expireUpdateTTL: Long = 0L, expireGetTTL: Long = 0L, expireMaxSize: Long = 0L, expireStoreSize: Long = 0L, expireCreateQueues: Array<QueueLong>? = if(expireCreateTTL<=0L) null else Array(stores.size, { i->QueueLong.make(store = stores[i])}), expireUpdateQueues: Array<QueueLong>? = if(expireUpdateTTL<=0L) null else Array(stores.size, { i->QueueLong.make(store = stores[i])}), expireGetQueues: Array<QueueLong>? = if(expireGetTTL<=0L) null else Array(stores.size, { i->QueueLong.make(store = stores[i])}), expireExecutor: ScheduledExecutorService? = null, expireExecutorPeriod: Long = 0, expireCompactThreshold: Double? = null, isThreadSafe: Boolean = true, valueLoader: (K) -> V = null, modificationListeners: Array<MapModificationListener<K, V>>? = null, closeable: Closeable? = null): HTreeMap<K, V>
        fun put(key: K?, value: V?): V?
        fun putAll(from: Map<out K?, V?>): Unit
        fun putIfAbsent(key: K?, value: V?): V?
        fun putIfAbsentBoolean(key: K?, value: V?): Boolean
        protected fun putprotected(hash: Int, key: K, value: V, triggered: Boolean): V?
        fun remove(key: K?): V?
        fun remove(key: Any?, value: Any?): Boolean
        protected fun removeprotected(hash: Int, key: K, evicted: Boolean): V?
        fun replace(key: K?, oldValue: V?, newValue: V?): Boolean
        fun replace(key: K?, value: V?): V?
        val size: Int
        fun sizeLong(): Long
        val stores: Array<Store>
        val valueInline: Boolean
        val valueLoader: (K) -> V?
        val valueSerializer: Serializer<V>
        protected fun valueUnwrap(segment: Int, wrappedValue: Any): V
        protected fun valueWrap(segment: Int, value: V): Any
        val values: MutableCollection<V?>
        fun verify(): Unit
      class IndexTreeList<E> : AbstractList<E?>
        Module Contents IndexTreeList(store: Store, serializer: Serializer<E>, map: <ERROR CLASS>, counterRecid: Long, isThreadSafe: Boolean)
        fun add(element: E?): Boolean
        fun add(index: Int, element: E?): Unit
        fun checkIndex(index: Int): Unit
        fun clear(): Unit
        val counterRecid: Long
        fun get(index: Int): E?
        fun isEmpty(): Boolean
        val isThreadSafe: Boolean
        fun iterator(): MutableIterator<E?>
        val lock: ReentrantReadWriteLock?
        val map: <ERROR CLASS>
        fun removeAt(index: Int): E?
        val serializer: Serializer<E>
        fun set(index: Int, element: E?): E?
        var size: Int
        val store: Store
      class IndexTreeLongLongMap
        Module Contents IndexTreeLongLongMap(store: Store, rootRecid: Long, dirShift: Int, levels: Int, collapseOnRemove: Boolean)
        fun addToValue(key: Long, toBeAdded: Long): Long
        fun allSatisfy(predicate: <ERROR CLASS>): Boolean
        fun anySatisfy(predicate: <ERROR CLASS>): Boolean
        fun appendString(appendable: Appendable, start: String, separator: String, end: String): Unit
        fun asSynchronized(): <ERROR CLASS>?
        fun asUnmodifiable(): <ERROR CLASS>?
        fun clear(): Unit
        val collapseOnRemove: Boolean
        fun <V> collect(function: <ERROR CLASS><out V>): MutableCollection<V>?
        fun contains(value: Long): Boolean
        fun containsKey(key: Long): Boolean
        fun containsValue(value: Long): Boolean
        fun count(predicate: <ERROR CLASS>): Int
        fun detectIfNone(predicate: <ERROR CLASS>, ifNone: Long): Long
        val dirShift: Int
        fun each(procedure: <ERROR CLASS>): Unit
        fun equals(other: Any?): Boolean
        fun forEach(procedure: <ERROR CLASS>): Unit
        fun forEachKey(procedure: <ERROR CLASS>): Unit
        fun forEachKeyValue(procedure: <ERROR CLASS>): Unit
        fun forEachValue(procedure: <ERROR CLASS>): Unit
        fun get(key: Long): Long
        fun getIfAbsent(key: Long, ifAbsent: Long): Long
        fun getIfAbsentPut(key: Long, function: <ERROR CLASS>): Long
        fun getIfAbsentPut(key: Long, value: Long): Long
        fun <P> getIfAbsentPutWith(key: Long, function: <ERROR CLASS><in P>, parameter: P): Long
        fun getIfAbsentPutWithKey(key: Long, function: <ERROR CLASS>): Long
        fun getOrThrow(key: Long): Long
        fun hashCode(): Int
        fun <T> injectInto(injectedValue: T, function: <ERROR CLASS><in T, out T>?): T
        fun keySet(): <ERROR CLASS>
        fun keyValuesView(): <ERROR CLASS><<ERROR CLASS>>
        fun keysView(): <ERROR CLASS>
        val levels: Int
        fun longIterator(): <ERROR CLASS>
        fun make(store: Store = StoreTrivial(), rootRecid: Long = store.put(dirEmpty(), dirSer), dirShift: Int = CC.INDEX_TREE_LONGLONGMAP_DIR_SHIFT, levels: Int = CC.INDEX_TREE_LONGLONGMAP_LEVELS, collapseOnRemove: Boolean = true): IndexTreeLongLongMap
        fun max(): Long
        fun min(): Long
        fun noneSatisfy(predicate: <ERROR CLASS>): Boolean
        fun put(key: Long, value: Long): Unit
        fun putAll(map: <ERROR CLASS>): Unit
        fun reject(predicate: <ERROR CLASS>): <ERROR CLASS>?
        fun reject(predicate: <ERROR CLASS>): <ERROR CLASS>
        fun remove(key: Long): Unit
        fun removeKey(key: Long): Unit
        fun removeKeyIfAbsent(key: Long, value: Long): Long
        val rootRecid: Long
        fun select(predicate: <ERROR CLASS>): <ERROR CLASS>?
        fun select(predicate: <ERROR CLASS>): <ERROR CLASS>?
        fun size(): Int
        val store: Store
        fun sum(): Long
        fun toArray(): LongArray
        fun toImmutable(): <ERROR CLASS>
        fun toString(): String
        fun updateValue(key: Long, initialValueIfAbsent: Long, function: <ERROR CLASS>): Long
        fun values(): <ERROR CLASS>
        fun withKeyValue(key: Long, value: Long): <ERROR CLASS>?
        fun withoutAllKeys(keys: <ERROR CLASS>): <ERROR CLASS>?
        fun withoutKey(key: Long): <ERROR CLASS>?
      interface MapExtra<K, V> : ConcurrentMap<K, V>
        Module Contents abstract fun forEach(action: BiConsumer<in K, in V>): Unit
        abstract fun forEachKey(procedure: (K) -> Unit): Unit
        abstract fun forEachValue(procedure: (V) -> Unit): Unit
        abstract fun isClosed(): Boolean
        abstract val keySerializer: Serializer<K>
        abstract fun putIfAbsentBoolean(key: K?, value: V?): Boolean
        abstract fun sizeLong(): Long
        abstract val valueSerializer: Serializer<V>
      object Pump
        Module Contents abstract class Sink<E, R>
          Module Contents Sink()
          abstract fun create(): R
          abstract fun put(e: E): Unit
          fun putAll(i: Iterable<E>): Unit
          fun putAll(i: Iterator<E>): Unit
        fun <K, V> treeMap(store: Store, keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>, comparator: Comparator<K> = keySerializer, leafNodeSize: Int = CC.BTREEMAP_MAX_NODE_SIZE*3/4, dirNodeSize: Int = CC.BTREEMAP_MAX_NODE_SIZE*3/4): Sink<<ERROR CLASS><K, V>, Unit>
      class QueueLong : Verifiable
        Module Contents QueueLong(store: Store, tailRecid: Long, headRecid: Long, headPrevRecid: Long)
        data class Node
          Module Contents Node(prevRecid: Long, nextRecid: Long, timestamp: Long, value: Long)
          object SERIALIZER : Serializer<Node>
            Module Contents fun deserialize(input: DataInput2, available: Int): Node?
            fun serialize(out: DataOutput2, value: Node): Unit
          val nextRecid: Long
          val prevRecid: Long
          val timestamp: Long
          val value: Long
        fun bump(nodeRecid: Long, newTimestamp: Long): Unit
        fun clear(): Unit
        fun forEach(body: (Long, Long, Long) -> Unit): Unit
        var head: Long
        var headPrev: Long
        val headPrevRecid: Long
        val headRecid: Long
        fun make(store: Store = StoreTrivial(), tailRecid: Long = store.put(store.put(null, Node.SERIALIZER), Serializer.RECID), headRecid: Long = store.put(store.get(tailRecid, Serializer.RECID), Serializer.RECID), headPrevRecid: Long = store.put(0L, Serializer.RECID)): QueueLong
        fun printContent(out: PrintStream): Unit
        fun put(timestamp: Long, value: Long): Long
        fun put(timestamp: Long, value: Long, nodeRecid: Long): Unit
        fun remove(nodeRecid: Long, removeNode: Boolean): Node
        fun size(): Long
        val store: Store
        var tail: Long
        val tailRecid: Long
        fun take(): Node?
        fun takeUntil(f: QueueLongTakeUntil): Unit
        fun valuesArray(): LongArray
        fun verify(): Unit
      class ReadOnlyVolumeFactory : VolumeFactory
        Module Contents ReadOnlyVolumeFactory(volfab: VolumeFactory)
        fun exists(file: String?): Boolean
        fun handlesReadonly(): Boolean
        fun makeVolume(file: String?, readOnly: Boolean, fileLockWait: Long, sliceShift: Int, initSize: Long, fixedSize: Boolean): Volume?
        protected val volfab: VolumeFactory
      class SerializerElsa : GroupSerializerObjectArray<Any?>
        Module Contents SerializerElsa()
        fun deserialize(input: DataInput2, available: Int): Any?
        protected val ser: <ERROR CLASS>
        fun serialize(out: DataOutput2, value: Any): Unit
      class SortedTableMap<K, V> : ConcurrentMap<K, V>, ConcurrentNavigableMap<K, V>, ConcurrentNavigableMapExtra<K, V>
        Module Contents SortedTableMap(keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>, pageSize: Long, volume: Volume, hasValues: Boolean = false)
        class Maker<K, V>
          Module Contents Maker(_volume: Volume? = null, _keySerializer: GroupSerializer<K>? = null, _valueSerializer: GroupSerializer<V>? = null)
          protected val _keySerializer: GroupSerializer<K>?
          protected var _nodeSize: Int
          protected var _pageSize: Long
          protected val _valueSerializer: GroupSerializer<V>?
          protected val _volume: Volume?
          fun createFrom(pairs: Iterable<<ERROR CLASS><K, V>>): SortedTableMap<K, V>
          fun createFrom(map: Map<K, V>): SortedTableMap<K, V>
          fun createFromSink(): Sink<K, V>
          fun nodeSize(nodeSize: Int): Maker<K, V>
          fun pageSize(pageSize: Long): Maker<K, V>
        protected class NodeIterator
          Module Contents NodeIterator(map: SortedTableMap<*, *>, pageOffset: Long, pageWithHeadOffset: Long, pageNodeCount: Long, node: Long)
          fun keysOffset(): Long
          fun keysOffsetEnd(): Long
          fun keysSize(): Int
          fun loadKeys(): Array<Any>
          fun loadVals(keysSize: Int): Array<Any>
          fun moveToNext(): Boolean
          fun moveToPrev(): Boolean
          fun valsOffset(): Long
          fun valsOffsetEnd(): Long
        abstract class Sink<K, V> : Sink<<ERROR CLASS><K, V>, SortedTableMap<K, V>>
          Module Contents Sink()
          fun put(key: K, value: V): Unit
        fun ceilingEntry(key: K?): MutableEntry<K, V>?
        fun ceilingKey(key: K?): K?
        fun clear(): Unit
        fun close(): Unit
        val comparator: GroupSerializer<K>
        fun comparator(): Comparator<in K>?
        fun containsKey(key: K?): Boolean
        fun containsValue(value: V?): Boolean
        fun <K, V> create(volume: Volume, keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>): Maker<K, V>
        fun <K, V> createFromSink(keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>, volume: Volume, pageSize: Long = CC.PAGE_SIZE, nodeSize: Int = CC.BTREEMAP_MAX_NODE_SIZE): Sink<K, V>
        fun descendingEntryIterator(): MutableIterator<MutableEntry<K, V?>>
        fun descendingEntryIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<MutableEntry<K, V?>>
        fun descendingKeyIterator(): MutableIterator<K>
        fun descendingKeyIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<K>
        fun descendingKeySet(): NavigableSet<K>?
        fun descendingMap(): ConcurrentNavigableMap<K, V>
        protected fun descendingNodeIterator(): NodeIterator
        fun descendingValueIterator(): MutableIterator<V>
        fun descendingValueIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<V>
        val entries: MutableSet<MutableEntry<K, V>>
        fun entryIterator(): MutableIterator<MutableEntry<K, V>>
        fun entryIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<MutableEntry<K, V?>>
        fun equals(other: Any?): Boolean
        fun findHigher(key: K?, inclusive: Boolean): MutableEntry<K, V>?
        fun findHigherKey(key: K?, inclusive: Boolean): K?
        fun findLower(key: K?, inclusive: Boolean): MutableEntry<K, V>?
        fun findLowerKey(key: K?, inclusive: Boolean): K?
        fun firstEntry(): MutableEntry<K, V>?
        fun firstKey(): K
        fun firstKey2(): K?
        fun floorEntry(key: K?): MutableEntry<K, V>?
        fun floorKey(key: K?): K?
        fun forEach(action: BiConsumer<in K, in V>): Unit
        fun forEachKey(procedure: (K) -> Unit): Unit
        fun forEachValue(procedure: (V) -> Unit): Unit
        fun get(key: K?): V?
        val hasValues: Boolean
        fun headMap(toKey: K?, inclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun headMap(toKey: K): ConcurrentNavigableMap<K, V>
        fun higherEntry(key: K?): MutableEntry<K, V>?
        fun higherKey(key: K?): K?
        fun isClosed(): Boolean
        fun isEmpty(): Boolean
        fun keyIterator(): MutableIterator<K>
        fun keyIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<K>
        val keySerializer: GroupSerializer<K>
        val keys: NavigableSet<K>
        fun lastEntry(): MutableEntry<K, V>?
        fun lastKey(): K
        fun lastKey2(): K?
        fun lowerEntry(key: K?): MutableEntry<K, V>?
        fun lowerKey(key: K?): K?
        fun navigableKeySet(): NavigableSet<K>?
        protected fun nodeIterator(): NodeIterator
        protected fun nodeIterator(lo: K): NodeIterator
        protected fun nodeSearch(key: K, offset: Long, offsetWithHead: Long, nodeCount: Int): Int
        fun <K, V> open(volume: Volume, keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>): SortedTableMap<K, V>
        val pageCount: Long
        protected val pageKeys: Any
        val pageSize: Long
        fun pollFirstEntry(): MutableEntry<K, V>?
        fun pollLastEntry(): MutableEntry<K, V>?
        fun put(key: K?, value: V?): V?
        fun putAll(from: Map<out K?, V?>): Unit
        fun putIfAbsent(key: K?, value: V?): V?
        fun putIfAbsentBoolean(key: K?, value: V?): Boolean
        fun remove(key: K?): V?
        fun remove(key: Any?, value: Any?): Boolean
        fun replace(key: K?, oldValue: V?, newValue: V?): Boolean
        fun replace(key: K?, value: V?): V?
        val size: Int
        val sizeLong: Long
        fun sizeLong(): Long
        fun subMap(fromKey: K?, fromInclusive: Boolean, toKey: K?, toInclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun subMap(fromKey: K, toKey: K): ConcurrentNavigableMap<K, V>
        fun tailMap(fromKey: K?, inclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun tailMap(fromKey: K): ConcurrentNavigableMap<K, V>
        fun valueIterator(): MutableIterator<V>
        fun valueIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<V>
        val valueSerializer: GroupSerializer<V>
        val values: MutableCollection<V>
        protected val volume: Volume
      interface Store : StoreImmutable, Verifiable, ConcurrencyAware
        Module Contents abstract fun close(): Unit
        abstract fun commit(): Unit
        abstract fun compact(): Unit
        abstract fun <R> compareAndSwap(recid: Long, expectedOldRecord: R?, newRecord: R?, serializer: Serializer<R>): Boolean
        abstract fun <R> delete(recid: Long, serializer: Serializer<R>): Unit
        abstract fun fileLoad(): Boolean
        abstract val isClosed: Boolean
        abstract val isReadOnly: Boolean
        abstract fun preallocate(): Long
        abstract fun <R> put(record: R?, serializer: Serializer<R>): Long
        abstract fun <R> update(recid: Long, record: R?, serializer: Serializer<R>): Unit
        abstract fun verify(): Unit
      interface StoreBinary : Store
        Module Contents abstract fun getBinaryLong(recid: Long, f: StoreBinaryGetLong): Long
      class StoreDirect : StoreDirectAbstract, StoreBinary
        Module Contents StoreDirect(file: String?, volumeFactory: VolumeFactory, isReadOnly: Boolean, fileLockWait: Long, isThreadSafe: Boolean, concShift: Int, allocateIncrement: Long, allocateStartSize: Long, fileDeleteAfterClose: Boolean, fileDeleteAfterOpen: Boolean, checksum: Boolean, checksumHeader: Boolean, checksumHeaderBypass: Boolean)
        protected fun allocateNewIndexPage(): Long
        protected fun allocateNewPage(): Long
        protected fun calculateFreeSize(): Long
        fun close(): Unit
        fun commit(): Unit
        fun compact(): Unit
        fun <R> compareAndSwap(recid: Long, expectedOldRecord: R?, newRecord: R?, serializer: Serializer<R>): Boolean
        fun <R> delete(recid: Long, serializer: Serializer<R>): Unit
        fun fileLoad(): Boolean
        protected val freeSize: AtomicLong
        protected fun freeSizeIncrement(increment: Long): Unit
        fun <R> get(recid: Long, serializer: Serializer<R>): R?
        fun getAllFiles(): Iterable<String>
        fun getAllRecids(): LongIterator
        fun getBinaryLong(recid: Long, f: StoreBinaryGetLong): Long
        fun getFreeSize(): Long
        protected fun getIndexVal(recid: Long): Long
        fun getTotalSize(): Long
        protected val headVol: Volume
        val isReadOnly: Boolean
        protected fun linkedRecordDelete(indexValue: Long): Unit
        protected fun linkedRecordGet(indexValue: Long): ByteArray
        protected fun linkedRecordPut(output: ByteArray, size: Int): Long
        protected fun longStackFindEnd(pageOffset: Long, pos: Long): Long
        protected fun longStackForEach(masterLinkOffset: Long, body: (Long) -> Unit): Unit
        protected fun longStackNewChunk(masterLinkOffset: Long, prevPageOffset: Long, value: Long, valueSize: Long, recursive: Boolean): Unit
        protected fun longStackPut(masterLinkOffset: Long, value: Long, recursive: Boolean): Unit
        protected fun longStackTake(masterLinkOffset: Long, recursive: Boolean): Long
        fun make(file: String? = null, volumeFactory: VolumeFactory = if(file==null) CC.DEFAULT_MEMORY_VOLUME_FACTORY else CC.DEFAULT_FILE_VOLUME_FACTORY, fileLockWait: Long = 0L, isReadOnly: Boolean = false, isThreadSafe: Boolean = true, concShift: Int = CC.STORE_DIRECT_CONC_SHIFT, allocateIncrement: Long = CC.PAGE_SIZE, allocateStartSize: Long = 0L, fileDeleteAfterClose: Boolean = false, fileDeleteAfterOpen: Boolean = false, checksum: Boolean = false, checksumHeader: Boolean = true, checksumHeaderBypass: Boolean = false): StoreDirect
        fun preallocate(): Long
        fun <R> put(record: R?, serializer: Serializer<R>): Long
        protected fun setIndexVal(recid: Long, value: Long): Unit
        fun <R> update(recid: Long, record: R?, serializer: Serializer<R>): Unit
        fun verify(): Unit
        protected val volume: Volume
      abstract class StoreDirectAbstract : Store
        Module Contents StoreDirectAbstract(file: String?, volumeFactory: VolumeFactory, isThreadSafe: Boolean, concShift: Int, fileDeleteAfterClose: Boolean, checksum: Boolean, checksumHeader: Boolean, checksumHeaderBypass: Boolean)
        protected fun allocateData(size: Int, recursive: Boolean): Long
        protected abstract fun allocateNewIndexPage(): Long
        protected abstract fun allocateNewPage(): Long
        protected fun allocateRecid(): Long
        protected fun assertNotClosed(): Unit
        fun calculateChecksum(): Long
        fun calculateHeaderChecksum(): Int
        val checksum: Boolean
        val checksumHeader: Boolean
        val checksumHeaderBypass: Boolean
        protected val closed: AtomicBoolean
        val concShift: Int
        protected var dataTail: Long
        protected fun <R> deserialize(serializer: Serializer<R>, di: DataInput2, size: Long): R?
        val file: String?
        val fileDeleteAfterClose: Boolean
        protected fun fileHeaderCheck(): Unit
        protected fun fileHeaderCompose(): Long
        protected abstract fun freeSizeIncrement(increment: Long): Unit
        protected abstract fun getIndexVal(recid: Long): Long
        protected abstract val headVol: Volume
        protected val indexPages: <ERROR CLASS>
        protected fun indexValCompose(size: Long, offset: Long, linked: Int, unused: Int, archive: Int): Long
        protected fun indexValFlagArchive(indexValue: Long): Boolean
        protected fun indexValFlagLinked(indexValue: Long): Boolean
        protected fun indexValFlagUnused(indexValue: Long): Boolean
        open val isClosed: Boolean
        open val isThreadSafe: Boolean
        protected fun loadIndexPages(indexPages: <ERROR CLASS>): Unit
        protected val locks: Array<ReadWriteLock?>
        protected fun longStackMasterLinkOffset(size: Long): Long
        protected abstract fun longStackPut(masterLinkOffset: Long, value: Long, recursive: Boolean): Unit
        protected abstract fun longStackTake(masterLinkOffset: Long, recursive: Boolean): Long
        protected var maxRecid: Long
        protected fun recidToOffset(recid2: Long): Long
        protected fun recidToSegment(recid: Long): Int
        protected fun releaseData(size: Long, offset: Long, recursive: Boolean): Unit
        protected fun releaseRecid(recid: Long): Unit
        protected val segmentCount: Int
        protected val segmentMask: Long
        protected fun <R> serialize(record: R?, serializer: Serializer<R>): DataOutput2?
        protected abstract fun setIndexVal(recid: Long, value: Long): Unit
        fun storeHeaderCompose(): Int
        protected val structuralLock: Lock?
        protected abstract val volume: Volume
        protected val volumeExistsAtStart: Boolean
        val volumeFactory: VolumeFactory
      interface StoreImmutable
        Module Contents abstract fun <R> get(recid: Long, serializer: Serializer<R>): R?
        abstract fun getAllFiles(): Iterable<String>
        abstract fun getAllRecids(): LongIterator
      class StoreOnHeap : Store
        Module Contents StoreOnHeap(isThreadSafe: Boolean = true)
        fun close(): Unit
        fun commit(): Unit
        fun compact(): Unit
        fun <R> compareAndSwap(recid: Long, expectedOldRecord: R?, newRecord: R?, serializer: Serializer<R>): Boolean
        fun <R> delete(recid: Long, serializer: Serializer<R>): Unit
        fun fileLoad(): Boolean
        fun <R> get(recid: Long, serializer: Serializer<R>): R?
        fun getAllFiles(): Iterable<String>
        fun getAllRecids(): LongIterator
        val isClosed: Boolean
        val isReadOnly: Boolean
        val isThreadSafe: Boolean
        fun preallocate(): Long
        fun <R> put(record: R?, serializer: Serializer<R>): Long
        fun <R> update(recid: Long, record: R?, serializer: Serializer<R>): Unit
        fun verify(): Unit
      class StoreReadOnlyWrapper : Store
        Module Contents StoreReadOnlyWrapper(store: Store)
        fun close(): Unit
        fun commit(): Unit
        fun compact(): Unit
        fun <R> compareAndSwap(recid: Long, expectedOldRecord: R?, newRecord: R?, serializer: Serializer<R>): Boolean
        fun <R> delete(recid: Long, serializer: Serializer<R>): Unit
        fun fileLoad(): Boolean
        fun <R> get(recid: Long, serializer: Serializer<R>): R?
        fun getAllFiles(): Iterable<String>
        fun getAllRecids(): LongIterator
        val isClosed: Boolean
        val isReadOnly: Boolean
        val isThreadSafe: Boolean
        fun preallocate(): Long
        fun <R> put(record: R?, serializer: Serializer<R>): Long
        protected val store: Store
        fun <R> update(recid: Long, record: R?, serializer: Serializer<R>): Unit
        fun verify(): Unit
      open class StoreTrivial : Store
        Module Contents StoreTrivial(isThreadSafe: Boolean = true)
        fun clear(): Unit
        open fun close(): Unit
        open fun commit(): Unit
        open fun compact(): Unit
        open fun <R> compareAndSwap(recid: Long, expectedOldRecord: R?, newRecord: R?, serializer: Serializer<R>): Boolean
        open fun <R> delete(recid: Long, serializer: Serializer<R>): Unit
        open fun equals(other: Any?): Boolean
        protected fun fileHeaderCheck(header: Long): Unit
        protected fun fileHeaderCompose(): Long
        open fun fileLoad(): Boolean
        open fun <R> get(recid: Long, serializer: Serializer<R>): R?
        open fun getAllFiles(): Iterable<String>
        open fun getAllRecids(): LongIterator
        open val isClosed: Boolean
        open val isReadOnly: Boolean
        open val isThreadSafe: Boolean
        fun loadFrom(inStream: InputStream): Unit
        protected fun loadFromInternal(inStream: InputStream): Unit
        protected val lock: ReadWriteLock?
        open fun preallocate(): Long
        open fun <R> put(record: R?, serializer: Serializer<R>): Long
        fun saveTo(outStream: OutputStream): Unit
        open fun <R> update(recid: Long, record: R?, serializer: Serializer<R>): Unit
        open fun verify(): Unit
      class StoreTrivialTx : StoreTrivial, StoreTx
        Module Contents StoreTrivialTx(file: File, isThreadSafe: Boolean = true, deleteFilesAfterClose: Boolean = false)
        fun close(): Unit
        fun commit(): Unit
        val deleteFilesAfterClose: Boolean
        val file: File
        fun getAllFiles(): Iterable<String>
        protected fun loadFrom(number: Long): Unit
        val path: Path
        fun rollback(): Unit
      interface StoreTx : Store
        Module Contents abstract fun rollback(): Unit
      class StoreWAL : StoreDirectAbstract, StoreTx
        Module Contents StoreWAL(file: String?, volumeFactory: VolumeFactory, fileLockWait: Long, isThreadSafe: Boolean, concShift: Int, allocateIncrement: Long, allocateStartSize: Long, fileDeleteAfterClose: Boolean, fileDeleteAfterOpen: Boolean, checksum: Boolean, checksumHeader: Boolean, checksumHeaderBypass: Boolean)
        protected val TOMB1: Long
        protected fun allocateNewIndexPage(): Long
        protected fun allocateNewPage(): Long
        protected val allocatedPages: <ERROR CLASS>
        protected val cacheIndexLinks: <ERROR CLASS>
        protected val cacheIndexVals: <ERROR CLASS>
        protected val cacheRecords: <ERROR CLASS>
        protected val cacheStacks: <ERROR CLASS>
        fun close(): Unit
        fun commit(): Unit
        fun compact(): Unit
        fun <R> compareAndSwap(recid: Long, expectedOldRecord: R?, newRecord: R?, serializer: Serializer<R>): Boolean
        fun <R> delete(recid: Long, serializer: Serializer<R>): Unit
        fun fileLoad(): Boolean
        protected fun freeSizeIncrement(increment: Long): Unit
        fun <R> get(recid: Long, serializer: Serializer<R>): R?
        fun getAllFiles(): Iterable<String>
        fun getAllRecids(): LongIterator
        protected fun getIndexVal(recid: Long): Long
        protected val headBytes: ByteArray
        protected val headVol: SingleByteArrayVol
        protected var indexPagesBackup: LongArray
        val isReadOnly: Boolean
        protected fun linkedRecordDelete(indexValue: Long, recid: Long): Unit
        protected fun linkedRecordGet(indexValue: Long, recid: Long): ByteArray
        protected fun linkedRecordPut(output: ByteArray, size: Int, recid: Long): Long
        protected fun longStackFindEnd(pageOffset: Long, pos: Long): Long
        protected fun longStackNewChunk(masterLinkOffset: Long, prevPageOffset: Long, value: Long, valueSize: Long, recursive: Boolean): Unit
        protected fun longStackPut(masterLinkOffset: Long, value: Long, recursive: Boolean): Unit
        protected fun longStackTake(masterLinkOffset: Long, recursive: Boolean): Long
        fun make(file: String? = null, volumeFactory: VolumeFactory = if(file==null) CC.DEFAULT_MEMORY_VOLUME_FACTORY else CC.DEFAULT_FILE_VOLUME_FACTORY, fileLockWait: Long = 0L, isThreadSafe: Boolean = true, concShift: Int = CC.STORE_DIRECT_CONC_SHIFT, allocateIncrement: Long = CC.PAGE_SIZE, allocateStartSize: Long = 0L, fileDeleteAfterClose: Boolean = false, fileDelteAfterOpen: Boolean = false, checksum: Boolean = false, checksumHeader: Boolean = true, checksumHeaderBypass: Boolean = false): StoreWAL
        fun preallocate(): Long
        fun <R> put(record: R?, serializer: Serializer<R>): Long
        protected val realVolume: Volume
        fun rollback(): Unit
        protected fun setIndexVal(recid: Long, value: Long): Unit
        fun <R> update(recid: Long, record: R?, serializer: Serializer<R>): Unit
        fun verify(): Unit
        protected val volume: Volume
        protected val wal: WriteAheadLog
      interface Verifiable
        Module Contents abstract fun verify(): Unit
    package org.mapdb
      Module Contents class Atomic
        Module Contents class Boolean
          Module Contents Boolean(store: Store, recid: Long)
          fun compareAndSet(expect: Boolean, update: Boolean): Boolean
          fun get(): Boolean
          fun getAndSet(newValue: Boolean): Boolean
          fun getRecid(): Long
          fun set(newValue: Boolean): Unit
          fun toString(): String
        class Integer : Number
          Module Contents Integer(store: Store, recid: Long)
          fun addAndGet(delta: Int): Int
          fun compareAndSet(expect: Int, update: Int): Boolean
          fun decrementAndGet(): Int
          fun get(): Int
          fun getAndAdd(delta: Int): Int
          fun getAndDecrement(): Int
          fun getAndIncrement(): Int
          fun getAndSet(newValue: Int): Int
          fun getRecid(): Long
          fun incrementAndGet(): Int
          fun set(newValue: Int): Unit
          fun toDouble(): Double
          fun toFloat(): Float
          fun toInt(): Int
          fun toLong(): Long
          fun toString(): String
        class Long : Number
          Module Contents Long(store: Store, recid: Long)
          fun addAndGet(delta: Long): Long
          fun compareAndSet(expect: Long, update: Long): Boolean
          fun decrementAndGet(): Long
          fun get(): Long
          fun getAndAdd(delta: Long): Long
          fun getAndDecrement(): Long
          fun getAndIncrement(): Long
          fun getAndSet(newValue: Long): Long
          fun getRecid(): Long
          fun incrementAndGet(): Long
          fun set(newValue: Long): Unit
          fun toDouble(): Double
          fun toFloat(): Float
          fun toInt(): Int
          fun toLong(): Long
          fun toString(): String
        class String
          Module Contents String(store: Store, recid: Long)
          fun compareAndSet(expect: String, update: String): Boolean
          fun get(): String
          fun getAndSet(newValue: String): String
          fun getRecid(): Long
          fun set(newValue: String): Unit
          fun toString(): String
        class Var<E : Any>
          Module Contents Var(store: Store, recid: Long, serializer: Serializer<E>)
          fun compareAndSet(expect: E, update: E): Boolean
          fun get(): E
          fun getAndSet(newValue: E): E
          fun getRecid(): Long
          fun set(newValue: E): Unit
          fun toString(): String
      class BTreeMap<K, V> : Verifiable, Closeable, Serializable, ConcurrencyAware, ConcurrentNavigableMap<K, V>, ConcurrentNavigableMapExtra<K, V>
        Module Contents BTreeMap(keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>, rootRecidRecid: Long, store: Store, valueInline: Boolean, maxNodeSize: Int, comparator: Comparator<K>, isThreadSafe: Boolean, counterRecid: Long, hasValues: Boolean, modificationListeners: Array<MapModificationListener<K, V>>?)
        abstract class BTreeBoundIterator<K, V>
          Module Contents BTreeBoundIterator(m: BTreeMap<K, V>, lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean)
          protected fun advance(): Unit
          protected fun checkHiBound(): Unit
          protected var currentLeaf: Node?
          protected var currentPos: Int
          fun hasNext(): Boolean
          val hi: K?
          protected val hiC: Int
          val hiInclusive: Boolean
          protected var lastReturnedKey: K?
          val lo: K?
          val loInclusive: Boolean
          val m: BTreeMap<K, V>
          fun remove(): Unit
        abstract class BTreeIterator<K, V>
          Module Contents BTreeIterator(m: BTreeMap<K, V>)
          protected fun advance(): Unit
          protected var currentLeaf: Node?
          protected var currentPos: Int
          fun hasNext(): Boolean
          protected var lastReturnedKey: K?
          val m: BTreeMap<K, V>
          fun remove(): Unit
        abstract class DescendingBoundIterator<K, V>
          Module Contents DescendingBoundIterator(m: BTreeMap<K, V>, lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean)
          protected fun advance(): Unit
          protected fun advanceNode(): Unit
          protected fun checkLoBound(): Unit
          protected var currentLeaf: Node?
          protected var currentPos: Int
          protected val descLeafIter: Iterator<Node>
          fun hasNext(): Boolean
          val hi: K?
          val hiInclusive: Boolean
          protected var lastReturnedKey: K?
          val lo: K?
          protected val loC: Int
          val loInclusive: Boolean
          val m: BTreeMap<K, V>
          fun remove(): Unit
        abstract class DescendingIterator<K, V>
          Module Contents DescendingIterator(m: BTreeMap<K, V>)
          protected fun advance(): Unit
          protected fun advanceNode(): Unit
          protected var currentLeaf: Node?
          protected var currentPos: Int
          protected val descLeafIter: Iterator<Node>
          fun hasNext(): Boolean
          protected var lastReturnedKey: K?
          val m: BTreeMap<K, V>
          fun remove(): Unit
        fun assertCurrentThreadUnlocked(): Unit
        protected fun btreeEntry(key: K, valueOrig: V?): MutableEntry<K, V?>
        fun ceilingEntry(key: K?): MutableEntry<K, V>?
        fun ceilingKey(key: K?): K?
        fun checkThreadSafe(): Unit
        fun clear(): Unit
        fun close(): Unit
        fun comparator(): Comparator<in K>?
        val comparator: Comparator<K>
        fun containsKey(key: K): Boolean
        fun containsValue(value: V): Boolean
        val counterRecid: Long
        fun descendingEntryIterator(): MutableIterator<MutableEntry<K, V?>>
        fun descendingEntryIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<MutableEntry<K, V?>>
        fun descendingKeyIterator(): MutableIterator<K>
        fun descendingKeyIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<K>
        fun descendingKeySet(): NavigableSet<K>?
        fun descendingLeafIterator(hi: K?): Iterator<Node>
        fun descendingMap(): ConcurrentNavigableMap<K, V>?
        fun descendingValueIterator(): MutableIterator<V?>
        fun descendingValueIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<V?>
        val entries: MutableSet<MutableEntry<K, V?>>
        fun entryIterator(): MutableIterator<MutableEntry<K, V?>>
        fun entryIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<MutableEntry<K, V?>>
        fun equals(other: Any?): Boolean
        fun findHigher(key: K?, inclusive: Boolean): MutableEntry<K, V>?
        fun findHigherKey(key: K?, inclusive: Boolean): K?
        fun findLower(key: K?, inclusive: Boolean): MutableEntry<K, V>?
        fun findLowerKey(key: K?, inclusive: Boolean): K?
        fun firstEntry(): MutableEntry<K, V?>?
        fun firstKey(): K
        fun firstKey2(): K?
        fun floorEntry(key: K?): MutableEntry<K, V>?
        fun floorKey(key: K): K?
        fun forEach(action: BiConsumer<in K, in V>?): Unit
        fun forEachKey(procedure: (K) -> Unit): Unit
        fun forEachValue(procedure: (V) -> Unit): Unit
        operator fun get(key: K?): V?
        val hasValues: Boolean
        fun hashCode(): Int
        fun headMap(toKey: K?, inclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun headMap(toKey: K): ConcurrentNavigableMap<K, V>
        fun higherEntry(key: K?): MutableEntry<K, V>?
        fun higherKey(key: K?): K?
        fun isClosed(): Boolean
        fun isEmpty(): Boolean
        val isThreadSafe: Boolean
        fun keyIterator(): MutableIterator<K>
        fun keyIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<K>
        val keySerializer: GroupSerializer<K>
        val keys: NavigableSet<K?>
        fun lastEntry(): MutableEntry<K, V?>?
        fun lastKey(): K
        fun lastKey2(): K?
        protected val leftEdges: <ERROR CLASS>
        protected fun listenerNotify(key: K, oldValue: V?, newValue: V?, triggered: Boolean): Unit
        fun lock(nodeRecid: Long): Unit
        protected val locks: ConcurrentHashMap<Long, Long>
        fun lowerEntry(key: K?): MutableEntry<K, V>?
        fun lowerKey(key: K): K?
        fun <K, V> make(keySerializer: GroupSerializer<K> = Serializer.ELSA as GroupSerializer<K>, valueSerializer: GroupSerializer<V> = Serializer.ELSA as GroupSerializer<V>, store: Store = StoreTrivial(), valueInline: Boolean = true, rootRecidRecid: Long = putEmptyRoot(store, keySerializer, if(valueInline) valueSerializer else Serializer.RECID), maxNodeSize: Int = CC.BTREEMAP_MAX_NODE_SIZE, comparator: Comparator<K> = keySerializer, isThreadSafe: Boolean = true, counterRecid: Long = 0L, hasValues: Boolean = true, modificationListeners: Array<MapModificationListener<K, V>>? = null): BTreeMap<K, V>
        val maxNodeSize: Int
        fun navigableKeySet(): NavigableSet<K?>
        protected val nodeSerializer: NodeSerializer
        fun pollFirstEntry(): MutableEntry<K, V?>?
        fun pollLastEntry(): MutableEntry<K, V?>?
        fun prefixSubMap(prefix: K): ConcurrentNavigableMap<K, V>
        fun prefixSubMap(prefix: K, inclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun printStructure(out: PrintStream): Unit
        fun put(key: K?, value: V?): V?
        protected fun put2(key: K, value: V, onlyIfAbsent: Boolean): V?
        fun putAll(from: Map<out K?, V?>): Unit
        fun putIfAbsent(key: K?, value: V?): V?
        fun putIfAbsentBoolean(key: K?, value: V?): Boolean
        fun remove(key: K?): V?
        fun remove(key: Any?, value: Any?): Boolean
        protected fun removeOrReplace(key: K, expectedOldValue: V?, replaceWithValue: V?): V?
        fun replace(key: K?, oldValue: V?, newValue: V?): Boolean
        fun replace(key: K?, value: V?): V?
        protected val rootRecid: Long
        val rootRecidRecid: Long
        val size: Int
        fun sizeLong(): Long
        val store: Store
        fun subMap(fromKey: K?, fromInclusive: Boolean, toKey: K?, toInclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun subMap(fromKey: K, toKey: K): ConcurrentNavigableMap<K, V>
        fun tailMap(fromKey: K?, inclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun tailMap(fromKey: K): ConcurrentNavigableMap<K, V>
        fun unlock(nodeRecid: Long): Unit
        fun unlockAllCurrentThread(): Unit
        protected fun valueExpand(v: Any?): V?
        val valueInline: Boolean
        fun valueIterator(): MutableIterator<V?>
        fun valueIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<V?>
        protected val valueNodeSerializer: GroupSerializer<Any>
        val valueSerializer: GroupSerializer<V>
        val values: MutableCollection<V?>
        fun verify(): Unit
      open class BTreeMapJava
        Module Contents BTreeMapJava()
        open class BinaryGet<K : Any, V : Any> : StoreBinaryGetLong
          Module Contents BinaryGet(keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>, comparator: Comparator<K>, key: K)
          open fun get(input: DataInput2, size: Int): Long
        static val COMPARABLE_COMPARATOR: Comparator<Any>
        interface ConcurrentNavigableMap2<K : Any, V : Any> : ConcurrentNavigableMap<K, V>
          Module Contents abstract fun firstKey2(): K
          abstract fun lastKey2(): K
        class KeySet<E : Any> : AbstractSet<E>, NavigableSet<E>, Closeable, Serializable
          Module Contents fun add(element: E): Boolean
          fun ceiling(e: E): E
          fun clear(): Unit
          fun close(): Unit
          fun comparator(): Comparator<in E>
          fun contains(element: E): Boolean
          fun descendingIterator(): MutableIterator<E>
          fun descendingSet(): NavigableSet<E>
          fun equals(other: Any?): Boolean
          fun first(): E
          fun floor(e: E): E
          fun headSet(toElement: E, inclusive: Boolean): NavigableSet<E>
          fun headSet(toElement: E): NavigableSet<E>
          fun higher(e: E): E
          fun isEmpty(): Boolean
          fun iterator(): MutableIterator<E>
          fun last(): E
          fun lower(e: E): E
          fun pollFirst(): E
          fun pollLast(): E
          fun remove(element: E): Boolean
          val size: Int
          fun sizeLong(): Long
          fun subSet(fromElement: E, fromInclusive: Boolean, toElement: E, toInclusive: Boolean): NavigableSet<E>
          fun subSet(fromElement: E, toElement: E): NavigableSet<E>
          fun tailSet(fromElement: E, inclusive: Boolean): NavigableSet<E>
          fun tailSet(fromElement: E): NavigableSet<E>
          fun toArray(): Array<Any>
          fun <T : Any> toArray(a: Array<T>): Array<T>
        open class Node
          Module Contents open fun getChildren(): LongArray
          open fun <K : Any> highKey(keySerializer: GroupSerializer<K>): K
          open fun verifyNode(keySerializer: GroupSerializer<Any>, comparator: Comparator<Any>, valueSerializer: GroupSerializer<Any>): Unit
        open class NodeSerializer : Serializer<Node>
          Module Contents open fun deserialize(input: DataInput2, available: Int): Node
          open fun isTrusted(): Boolean
          open fun serialize(out: DataOutput2, value: Node): Unit
      interface CC
        Module Contents static val ASSERT: Boolean
        static val BTREEMAP_MAX_NODE_SIZE: Int
        static val DEFAULT_FILE_VOLUME_FACTORY: VolumeFactory
        static val DEFAULT_MEMORY_VOLUME_FACTORY: VolumeFactory
        static val FAIR_LOCK: Boolean
        static val FEAT_CHECKSUM_MASK: Int
        static val FEAT_CHECKSUM_SHIFT: Int
        static val FEAT_ENCRYPT_MASK: Int
        static val FEAT_ENCRYPT_SHIFT: Int
        static val FILE_HEADER: Long
        static val FILE_TYPE_SORTED_MULTI: Long
        static val FILE_TYPE_SORTED_SINGLE: Long
        static val FILE_TYPE_SORTED_WAL: Long
        static val FILE_TYPE_STOREDIRECT: Long
        static val FILE_TYPE_STORETRIVIAL: Long
        static val FILE_TYPE_STOREWAL_WAL: Long
        static val HASH_FACTORY: XXHashFactory
        static val HTREEMAP_CONC_SHIFT: Int
        static val HTREEMAP_DIR_SHIFT: Int
        static val HTREEMAP_LEVELS: Int
        static val INDEX_TREE_LONGLONGMAP_DIR_SHIFT: Int
        static val INDEX_TREE_LONGLONGMAP_LEVELS: Int
        static val LOG: Boolean
        static val LOG_VOLUME_GCED: Boolean
        static val LOG_WAL_CONTENT: Boolean
        static val PAGE_SHIFT: Int
        static val PAGE_SIZE: Long
        static val PARANOID: Boolean
        static val RECID_CLASS_INFOS: Long
        static val RECID_MAX_RESERVED: Long
        static val RECID_NAME_CATALOG: Long
        static val STORE_DIRECT_CONC_SHIFT: Int
        static val VOLUME_PRINT_STACK_AT_OFFSET: Long
        static val ZEROS: Boolean
      interface ConcurrencyAware
        Module Contents open fun checkThreadSafe(): Unit
        abstract val isThreadSafe: Boolean
      interface ConcurrentNavigableMapExtra<K, V> : ConcurrentNavigableMap<K, V>, MapExtra<K, V>, ConcurrentNavigableMap2<K, V>
        Module Contents abstract fun descendingEntryIterator(): MutableIterator<MutableEntry<K, V?>>
        abstract fun descendingEntryIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<MutableEntry<K, V?>>
        abstract fun descendingKeyIterator(): MutableIterator<K>
        abstract fun descendingKeyIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<K>
        abstract fun descendingValueIterator(): MutableIterator<V?>
        abstract fun descendingValueIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<V?>
        abstract fun entryIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<MutableEntry<K, V?>>
        abstract fun findHigher(key: K?, inclusive: Boolean): MutableEntry<K, V>?
        abstract fun findHigherKey(key: K?, inclusive: Boolean): K?
        abstract fun findLower(key: K?, inclusive: Boolean): MutableEntry<K, V>?
        abstract fun findLowerKey(key: K?, inclusive: Boolean): K?
        abstract val hasValues: Boolean
        abstract fun keyIterator(): MutableIterator<K>
        abstract fun keyIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<K?>
        abstract fun valueIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<V?>
      open class DB : Closeable, ConcurrencyAware
        Module Contents DB(store: Store, storeOpened: Boolean, isThreadSafe: Boolean = true, classLoader: ClassLoader = Thread.currentThread().contextClassLoader, shutdownHook: Int = 0)
        class AtomicBooleanMaker : Maker<Boolean>
          Module Contents AtomicBooleanMaker(db: DB, name: String, value: Boolean = false)
          protected fun create2(catalog: SortedMap<String, String>): Boolean
          protected val db: DB
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): Boolean
          protected val type: String
          protected val value: Boolean
        class AtomicIntegerMaker : Maker<Integer>
          Module Contents AtomicIntegerMaker(db: DB, name: String, value: Int = 0)
          protected fun create2(catalog: SortedMap<String, String>): Integer
          protected val db: DB
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): Integer
          protected val type: String
          protected val value: Int
        class AtomicLongMaker : Maker<Long>
          Module Contents AtomicLongMaker(db: DB, name: String, value: Long = 0)
          protected fun create2(catalog: SortedMap<String, String>): Long
          protected val db: DB
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): Long
          protected val type: String
          protected val value: Long
        class AtomicStringMaker : Maker<String>
          Module Contents AtomicStringMaker(db: DB, name: String, value: String? = null)
          protected fun create2(catalog: SortedMap<String, String>): String
          protected val db: DB
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): String
          protected val type: String
          protected val value: String?
        class AtomicVarMaker<E> : Maker<Var<E>>
          Module Contents AtomicVarMaker(db: DB, name: String, serializer: Serializer<E> = db.defaultSerializer as Serializer<E>, value: E? = null)
          protected fun create2(catalog: SortedMap<String, String>): Var<E>
          protected val db: DB
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): Var<E>
          protected val serializer: Serializer<E>
          protected val type: String
          protected val value: E?
        protected data class CatVal
          Module Contents CatVal(msg: (String) -> String?, required: Boolean = true)
          val msg: (String) -> String?
          val required: Boolean
        class HashMapMaker<K, V> : Maker<HTreeMap<K, V>>
          Module Contents HashMapMaker(db: DB, name: String, hasValues: Boolean = true, _storeFactory: (Int) -> Store = {i-> db.store})
          protected val _storeFactory: (Int) -> Store
          fun counterEnable(): HashMapMaker<K, V>
          fun create(): HTreeMap<K, V>
          protected fun create2(catalog: SortedMap<String, String>): HTreeMap<K, V>
          fun createOrOpen(): HTreeMap<K, V>
          protected val db: DB
          fun expireAfterCreate(): HashMapMaker<K, V>
          fun expireAfterCreate(ttl: Long): HashMapMaker<K, V>
          fun expireAfterCreate(ttl: Long, unit: TimeUnit): HashMapMaker<K, V>
          fun expireAfterGet(): HashMapMaker<K, V>
          fun expireAfterGet(ttl: Long): HashMapMaker<K, V>
          fun expireAfterGet(ttl: Long, unit: TimeUnit): HashMapMaker<K, V>
          fun expireAfterUpdate(): HashMapMaker<K, V>
          fun expireAfterUpdate(ttl: Long): HashMapMaker<K, V>
          fun expireAfterUpdate(ttl: Long, unit: TimeUnit): HashMapMaker<K, V>
          fun expireCompactThreshold(freeFraction: Double): HashMapMaker<K, V>
          fun expireExecutor(executor: ScheduledExecutorService?): HashMapMaker<K, V>
          fun expireExecutorPeriod(period: Long): HashMapMaker<K, V>
          fun expireMaxSize(maxSize: Long): HashMapMaker<K, V>
          fun expireOverflow(overflowMap: MutableMap<K, V?>): HashMapMaker<K, V>
          fun expireStoreSize(storeSize: Long): HashMapMaker<K, V>
          protected val hasValues: Boolean
          fun hashSeed(hashSeed: Int): HashMapMaker<K, V>
          fun <A> keySerializer(keySerializer: Serializer<A>): HashMapMaker<A, V>
          fun layout(concurrency: Int, dirSize: Int, levels: Int): HashMapMaker<K, V>
          fun modificationListener(listener: MapModificationListener<K, V>): HashMapMaker<K, V>
          protected val name: String
          fun open(): HTreeMap<K, V>
          protected fun open2(catalog: SortedMap<String, String>): HTreeMap<K, V>
          fun removeCollapsesIndexTreeDisable(): HashMapMaker<K, V>
          protected val type: String
          fun valueInline(): HashMapMaker<K, V>
          fun valueLoader(valueLoader: (K) -> V): HashMapMaker<K, V>
          fun <A> valueSerializer(valueSerializer: Serializer<A>): HashMapMaker<K, A>
          protected fun verify(): Unit
        class HashSetMaker<E> : Maker<KeySet<E>>
          Module Contents HashSetMaker(db: DB, name: String, _storeFactory: (Int) -> Store = {i-> db.store})
          protected val _storeFactory: (Int) -> Store
          fun counterEnable(): HashSetMaker<E>
          protected fun create2(catalog: SortedMap<String, String>): KeySet<E>
          protected val db: DB
          fun expireAfterCreate(): HashSetMaker<E>
          fun expireAfterCreate(ttl: Long): HashSetMaker<E>
          fun expireAfterCreate(ttl: Long, unit: TimeUnit): HashSetMaker<E>
          fun expireAfterGet(): HashSetMaker<E>
          fun expireAfterGet(ttl: Long): HashSetMaker<E>
          fun expireAfterGet(ttl: Long, unit: TimeUnit): HashSetMaker<E>
          fun expireCompactThreshold(freeFraction: Double): HashSetMaker<E>
          fun expireExecutor(executor: ScheduledExecutorService?): HashSetMaker<E>
          fun expireExecutorPeriod(period: Long): HashSetMaker<E>
          fun expireMaxSize(maxSize: Long): HashSetMaker<E>
          fun expireStoreSize(storeSize: Long): HashSetMaker<E>
          fun hashSeed(hashSeed: Int): HashSetMaker<E>
          fun layout(concurrency: Int, dirSize: Int, levels: Int): HashSetMaker<E>
          protected val maker: HashMapMaker<E, Any?>
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): KeySet<E>
          fun removeCollapsesIndexTreeDisable(): HashSetMaker<E>
          fun <A> serializer(serializer: Serializer<A>): HashSetMaker<A>
          protected val type: String
          protected fun verify(): Unit
        class IndexTreeListMaker<E> : Maker<IndexTreeList<E>>
          Module Contents IndexTreeListMaker(db: DB, name: String, serializer: Serializer<E>)
          protected fun create2(catalog: SortedMap<String, String>): IndexTreeList<E>
          protected val db: DB
          fun layout(dirSize: Int, levels: Int): IndexTreeListMaker<E>
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): IndexTreeList<E>
          fun removeCollapsesIndexTreeDisable(): IndexTreeListMaker<E>
          protected val serializer: Serializer<E>
          protected val type: String
        class IndexTreeLongLongMapMaker : Maker<IndexTreeLongLongMap>
          Module Contents IndexTreeLongLongMapMaker(db: DB, name: String)
          protected fun create2(catalog: SortedMap<String, String>): IndexTreeLongLongMap
          protected val db: DB
          fun layout(dirSize: Int, levels: Int): IndexTreeLongLongMapMaker
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): IndexTreeLongLongMap
          fun removeCollapsesIndexTreeDisable(): IndexTreeLongLongMapMaker
          protected val type: String
        object Keys
          Module Contents val concShift: String
          val counterRecid: String
          val counterRecids: String
          val dirShift: String
          val expireCreateQueue: String
          val expireCreateTTL: String
          val expireGetQueue: String
          val expireGetTTL: String
          val expireUpdateQueue: String
          val expireUpdateTTL: String
          val hashSeed: String
          val keySerializer: String
          val levels: String
          val maxNodeSize: String
          val recid: String
          val removeCollapsesIndexTree: String
          val rootRecid: String
          val rootRecidRecid: String
          val rootRecids: String
          val segmentRecids: String
          val serializer: String
          val size: String
          val type: String
          val valueInline: String
          val valueSerializer: String
        abstract class Maker<E>
          Module Contents Maker()
          open fun create(): E
          protected abstract fun create2(catalog: SortedMap<String, String>): E
          open fun createOrOpen(): E
          protected abstract val db: DB
          open fun make(): E
          protected fun make2(create: Boolean?): E
          open fun makeOrGet(): E
          protected abstract val name: String
          open fun open(): E
          protected abstract fun open2(catalog: SortedMap<String, String>): E
          protected abstract val type: String
          protected open fun verify(): Unit
        protected val NAMED_SERIALIZATION_HEADER: Int
        protected val NAME_CATALOG_SERIALIZER: Serializer<SortedMap<String, String>>
        class TreeMapMaker<K, V> : Maker<BTreeMap<K, V>>
          Module Contents TreeMapMaker(db: DB, name: String, hasValues: Boolean = true)
          fun counterEnable(): TreeMapMaker<K, V>
          fun create(): BTreeMap<K, V>
          protected fun create2(catalog: SortedMap<String, String>): BTreeMap<K, V>
          fun createFrom(iterator: Iterator<<ERROR CLASS><K, V>>): BTreeMap<K, V>
          fun createFromSink(): TreeMapSink<K, V>
          fun createOrOpen(): BTreeMap<K, V>
          protected val db: DB
          protected val hasValues: Boolean
          fun <A> keySerializer(keySerializer: GroupSerializer<A>): TreeMapMaker<A, V>
          fun maxNodeSize(size: Int): TreeMapMaker<K, V>
          fun modificationListener(listener: MapModificationListener<K, V>): TreeMapMaker<K, V>
          protected val name: String
          fun open(): BTreeMap<K, V>
          protected fun open2(catalog: SortedMap<String, String>): BTreeMap<K, V>
          protected val type: String
          fun <A> valueSerializer(valueSerializer: GroupSerializer<A>): TreeMapMaker<K, A>
          fun valuesOutsideNodesEnable(): TreeMapMaker<K, V>
        abstract class TreeMapSink<K, V> : Sink<<ERROR CLASS><K, V>, BTreeMap<K, V>>
          Module Contents TreeMapSink()
          fun put(key: K, value: V): Unit
          fun putAll(map: SortedMap<K, V>): Unit
        class TreeSetMaker<E> : Maker<NavigableSet<E>>
          Module Contents TreeSetMaker(db: DB, name: String)
          fun counterEnable(): TreeSetMaker<E>
          protected fun create2(catalog: SortedMap<String, String>): NavigableSet<E>
          protected val db: DB
          protected val maker: TreeMapMaker<E, Any?>
          fun maxNodeSize(size: Int): TreeSetMaker<E>
          protected val name: String
          protected fun open2(catalog: SortedMap<String, String>): NavigableSet<E>
          fun <A> serializer(serializer: GroupSerializer<A>): TreeSetMaker<A>
          protected val type: String
          protected fun verify(): Unit
        protected fun addShutdownHook(ref: Any): Unit
        fun atomicBoolean(name: String): AtomicBooleanMaker
        fun atomicBoolean(name: String, value: Boolean): AtomicBooleanMaker
        fun atomicInteger(name: String): AtomicIntegerMaker
        fun atomicInteger(name: String, value: Int): AtomicIntegerMaker
        fun atomicLong(name: String): AtomicLongMaker
        fun atomicLong(name: String, value: Long): AtomicLongMaker
        fun atomicString(name: String): AtomicStringMaker
        fun atomicString(name: String, value: String?): AtomicStringMaker
        fun atomicVar(name: String): AtomicVarMaker<Any?>
        fun <E> atomicVar(name: String, serializer: Serializer<E>): AtomicVarMaker<E>
        fun <E> atomicVar(name: String, serializer: Serializer<E>, value: E?): AtomicVarMaker<E>
        protected fun checkName(name: String): Unit
        protected fun checkNotClosed(): Unit
        open fun checkThreadSafe(): Unit
        protected val classInfoSerializer: Serializer<Array<<ERROR CLASS>>>
        val classLoader: ClassLoader
        open fun close(): Unit
        fun commit(): Unit
        val defaultSerializer: GroupSerializerObjectArray<Any?>
        fun defaultSerializerRegisterClass(clazz: Class<*>): Unit
        protected val executors: MutableSet<ExecutorService>
        fun exists(name: String): Boolean
        fun <E> get(name: String): E
        fun getAll(): Map<String, Any?>
        fun getAllNames(): Iterable<String>
        fun getNameForObject(e: Any): String?
        fun getStore(): Store
        fun hashMap(name: String): HashMapMaker<*, *>
        fun <K, V> hashMap(name: String, keySerializer: Serializer<K>, valueSerializer: Serializer<V>): HashMapMaker<K, V>
        fun hashSet(name: String): HashSetMaker<*>
        fun <E> hashSet(name: String, serializer: Serializer<E>): HashSetMaker<E>
        fun <E> indexTreeList(name: String, serializer: Serializer<E>): IndexTreeListMaker<E>
        fun indexTreeList(name: String): IndexTreeListMaker<Any?>
        fun isClosed(): Boolean
        open val isThreadSafe: Boolean
        protected val lock: ReentrantReadWriteLock?
        protected fun nameCatalogGet(name: String): String?
        fun <E> nameCatalogGetClass(nameCatalog: SortedMap<String, String>, key: String): E?
        fun nameCatalogLoad(): SortedMap<String, String>
        protected fun nameCatalogLoadLocked(): SortedMap<String, String>
        fun nameCatalogParamsFor(name: String): Map<String, String>
        fun nameCatalogPutClass(nameCatalog: SortedMap<String, String>, key: String, obj: Any): Unit
        fun nameCatalogSave(nameCatalog: SortedMap<String, String>): Unit
        protected fun nameCatalogSaveLocked(nameCatalog: SortedMap<String, String>): Unit
        fun nameCatalogVerifyGetMessages(): Iterable<String>
        protected var namesInstanciated: <ERROR CLASS><String, Any?>
        fun rollback(): Unit
        val shutdownHook: Int
        protected val storeOpened: Boolean
        fun treeMap(name: String): TreeMapMaker<*, *>
        fun <K, V> treeMap(name: String, keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>): TreeMapMaker<K, V>
        fun treeSet(name: String): TreeSetMaker<*>
        fun <E> treeSet(name: String, serializer: GroupSerializer<E>): TreeSetMaker<E>
      open class DBException : RuntimeException
        Module Contents DBException(message: String)
        DBException(message: String?, cause: Throwable?)
        open class DataCorruption : DBException
          Module Contents DataCorruption(msg: String)
        class FileLocked : DBException
          Module Contents FileLocked(path: Path, exception: Exception)
        class GetVoid : DBException
          Module Contents GetVoid(recid: Long)
        class Interrupted : DBException
          Module Contents Interrupted(e: InterruptedException)
        class NewMapDBFormat : DBException
          Module Contents NewMapDBFormat(message: String = "Store uses feature from newer version of MapDB, this MapDB version is old does not support new feature")
        class NotSorted : DBException
          Module Contents NotSorted()
        class OutOfMemory : VolumeIOError
          Module Contents OutOfMemory(e: Throwable)
        class PointerChecksumBroken : DataCorruption
          Module Contents PointerChecksumBroken()
        open class SerializationError : DBException
          Module Contents SerializationError(e: Throwable)
          SerializationError(msg: String)
          SerializationError(msg: String?, e: Throwable?)
        open class VolumeClosed : DBException
          Module Contents VolumeClosed(e: Throwable)
          VolumeClosed(msg: String)
          VolumeClosed(msg: String?, e: Throwable?)
        open class VolumeClosedByInterrupt : DBException
          Module Contents VolumeClosedByInterrupt(e: Throwable?)
        open class VolumeEOF : VolumeIOError
          Module Contents VolumeEOF(e: IOException)
          VolumeEOF(msg: String)
          VolumeEOF(msg: String?, e: IOException?)
        open class VolumeIOError : DBException
          Module Contents VolumeIOError(e: IOException)
          VolumeIOError(msg: String)
          VolumeIOError(msg: String?, e: Throwable?)
        class VolumeMaxSizeExceeded : DBException
          Module Contents VolumeMaxSizeExceeded(length: Long, requestedLength: Long)
        class WrongConfiguration : DBException
          Module Contents WrongConfiguration(message: String)
        class WrongFormat : DBException
          Module Contents WrongFormat(msg: String)
      object DBMaker
        Module Contents class Maker
          Module Contents Maker(_storeType: StoreType?, _customVolume: Volume? = null, _volumeExist: Boolean? = null, file: String? = null)
          fun allocateIncrement(incrementSize: Long): Maker
          fun allocateStartSize(size: Long): Maker
          protected fun assertFile(): Unit
          fun checksumHeaderBypass(): Maker
          fun checksumStoreEnable(): Maker
          fun cleanerHackEnable(): Maker
          fun closeOnJvmShutdown(): Maker
          fun closeOnJvmShutdownWeakReference(): Maker
          fun concurrencyDisable(): Maker
          fun concurrencyScale(segmentCount: Int): Maker
          fun deleteFilesAfterClose(): Maker
          fun executorEnable(): Maker
          fun fileChannelEnable(): Maker
          fun fileDeleteAfterClose(): Maker
          fun fileDeleteAfterOpen(): Maker
          fun fileLockDisable(): Maker
          fun fileLockWait(timeout: Long): Maker
          fun fileLockWait(): Maker
          fun fileMmapEnable(): Maker
          fun fileMmapEnableIfSupported(): Maker
          fun fileMmapPreclearDisable(): Maker
          fun make(): DB
          fun readOnly(): Maker
          fun transactionEnable(): Maker
        enum class StoreType
          Module Contents bytearray
          directbuffer
          fileChannel
          fileMMap
          fileRaf
          onheap
        fun fileDB(file: String): Maker
        fun fileDB(file: File): Maker
        fun heapDB(): Maker
        fun heapShardedHashMap(concurrency: Int): HashMapMaker<*, *>
        fun heapShardedHashSet(concurrency: Int): HashSetMaker<*>
        fun memoryDB(): Maker
        fun memoryDirectDB(): Maker
        fun memoryShardedHashMap(concurrency: Int): HashMapMaker<*, *>
        fun memoryShardedHashSet(concurrency: Int): HashSetMaker<*>
        fun tempFileDB(): Maker
        fun volumeDB(volume: Volume, volumeExists: Boolean): Maker
      class DataIO
        Module Contents static val PACK_LONG_RESULT_MASK: Long
        static fun arrayDelete(vals: Array<Any>, pos: Int, len: Int): Array<Any>
        static fun arrayDelete(vals: LongArray, pos: Int, len: Int): LongArray
        static fun arrayPut(array: Array<Any>, pos: Int, value: Any): Array<Any>
        static fun fillLowBits(bitCount: Int): Long
        static fun fromHexa(s: String): ByteArray
        static fun getInt(buf: ByteArray, pos: Int): Int
        static fun getLong(buf: ByteArray, pos: Int): Long
        static fun getSixLong(buf: ByteArray, pos: Int): Long
        static fun intHash(h: Int): Int
        static fun intToLong(i: Int): Long
        static fun longHash(h: Long): Int
        static fun nextPowTwo(a: Long): Long
        static fun nextPowTwo(a: Int): Int
        static fun packInt(out: DataOutput, value: Int): Unit
        static fun packInt(buf: ByteArray, pos: Int, value: Int): Int
        static fun packIntBigger(out: DataOutput, value: Int): Unit
        static fun packLong(out: DataOutput, value: Long): Unit
        static fun packLong(out: OutputStream, value: Long): Unit
        static fun packLong(buf: ByteArray, pos: Int, value: Long): Int
        static fun packLongSize(value: Long): Int
        static fun packRecid(out: DataOutput2, value: Long): Unit
        static fun parity16Get(i: Long): Long
        static fun parity16Set(i: Long): Long
        static fun parity1Get(i: Long): Long
        static fun parity1Get(i: Int): Int
        static fun parity1Set(i: Long): Long
        static fun parity1Set(i: Int): Int
        static fun parity3Get(i: Long): Long
        static fun parity3Set(i: Long): Long
        static fun parity4Get(i: Long): Long
        static fun parity4Set(i: Long): Long
        static fun putInt(buf: ByteArray, pos: Int, v: Int): Unit
        static fun putLong(buf: ByteArray, pos: Int, v: Long): Unit
        static fun putLong(buf: ByteArray, pos: Int, v: Long, vSize: Int): Unit
        static fun putSixLong(buf: ByteArray, pos: Int, value: Long): Unit
        static fun readFully(in: InputStream, data: ByteArray, offset: Int, len: Int): Unit
        static fun readFully(in: InputStream, data: ByteArray): Unit
        static fun roundDown(number: Long, roundDownToMultipleOf: Long): Long
        static fun roundDown(number: Int, roundDownToMultipleOf: Int): Int
        static fun roundUp(number: Long, roundUpToMultipleOf: Long): Long
        static fun roundUp(number: Int, roundUpToMultipleOf: Int): Int
        static fun shift(value: Int): Int
        static fun skipFully(in: InputStream, length: Long): Unit
        static fun toHexa(bb: ByteArray): String
        static fun unpackInt(is: DataInput): Int
        static fun unpackInt(in: InputStream): Int
        static fun unpackInt(buf: ByteArray, pos: Int): Int
        static fun unpackLong(in: DataInput): Long
        static fun unpackLong(in: InputStream): Long
        static fun unpackLong(buf: ByteArray, pos: Int): Long
        static fun unpackRecid(in: DataInput2): Long
        static fun writeFully(f: FileChannel, buf: ByteBuffer): Unit
      abstract class DataInput2 : DataInput
        Module Contents DataInput2()
        class ByteArray : DataInput2
          Module Contents ByteArray(b: ByteArray)
          ByteArray(bb: ByteArray, pos: Int)
          fun close(): Unit
          fun getPos(): Int
          fun internalByteArray(): ByteArray
          fun internalByteBuffer(): ByteBuffer
          var pos: Int
          fun readBoolean(): Boolean
          fun readByte(): Byte
          fun readChar(): Char
          fun readFully(b: ByteArray, off: Int, len: Int): Unit
          fun readInt(): Int
          fun readLong(): Long
          fun readShort(): Short
          fun readUnsignedByte(): Int
          fun setPos(pos: Int): Unit
          fun skipBytes(n: Int): Int
          fun unpackInt(): Int
          fun unpackIntArray(array: IntArray, start: Int, end: Int): Unit
          fun unpackLong(): Long
          fun unpackLongArray(array: LongArray, start: Int, end: Int): Unit
          fun unpackLongArrayDeltaCompression(size: Int): LongArray
          fun unpackLongSkip(count: Int): Unit
        class ByteBuffer : DataInput2
          Module Contents ByteBuffer(buf: ByteBuffer, pos: Int)
          val buf: ByteBuffer
          fun close(): Unit
          fun getPos(): Int
          fun internalByteArray(): ByteArray
          fun internalByteBuffer(): ByteBuffer
          var pos: Int
          fun readBoolean(): Boolean
          fun readByte(): Byte
          fun readChar(): Char
          fun readFully(b: ByteArray, off: Int, len: Int): Unit
          fun readInt(): Int
          fun readLong(): Long
          fun readShort(): Short
          fun readUnsignedByte(): Int
          fun setPos(pos: Int): Unit
          fun skipBytes(n: Int): Int
          fun unpackInt(): Int
          fun unpackIntArray(array: IntArray, start: Int, end: Int): Unit
          fun unpackLong(): Long
          fun unpackLongArray(array: LongArray, start: Int, end: Int): Unit
          fun unpackLongArrayDeltaCompression(size: Int): LongArray
          fun unpackLongSkip(count: Int): Unit
        class DataInputToStream : InputStream
          Module Contents DataInputToStream(in: DataInput)
          fun close(): Unit
          fun read(b: ByteArray, off: Int, len: Int): Int
          fun read(): Int
          fun skip(n: Long): Long
        class Stream : DataInput2
          Module Contents Stream(ins: InputStream)
          fun close(): Unit
          fun getPos(): Int
          fun internalByteArray(): ByteArray
          fun internalByteBuffer(): ByteBuffer
          fun readBoolean(): Boolean
          fun readByte(): Byte
          fun readChar(): Char
          fun readFully(b: ByteArray, off: Int, len: Int): Unit
          fun readInt(): Int
          fun readLong(): Long
          fun readShort(): Short
          fun readUnsignedByte(): Int
          fun setPos(pos: Int): Unit
          fun skipBytes(n: Int): Int
          fun unpackInt(): Int
          fun unpackIntArray(array: IntArray, start: Int, end: Int): Unit
          fun unpackLong(): Long
          fun unpackLongArray(array: LongArray, start: Int, end: Int): Unit
          fun unpackLongArrayDeltaCompression(size: Int): LongArray
          fun unpackLongSkip(count: Int): Unit
        abstract fun close(): Unit
        abstract fun getPos(): Int
        abstract fun internalByteArray(): ByteArray
        abstract fun internalByteBuffer(): ByteBuffer
        open fun readDouble(): Double
        open fun readFloat(): Float
        open fun readFully(b: ByteArray): Unit
        open fun readLine(): String
        open fun readUTF(): String
        open fun readUnsignedShort(): Int
        abstract fun setPos(pos: Int): Unit
        abstract fun unpackInt(): Int
        abstract fun unpackIntArray(ret: IntArray, i: Int, len: Int): Unit
        abstract fun unpackLong(): Long
        abstract fun unpackLongArray(ret: LongArray, i: Int, len: Int): Unit
        abstract fun unpackLongArrayDeltaCompression(size: Int): LongArray
        abstract fun unpackLongSkip(count: Int): Unit
      open class DataOutput2 : OutputStream, DataOutput
        Module Contents DataOutput2()
        var buf: ByteArray
        open fun copyBytes(): ByteArray
        open fun ensureAvail(n: Int): Unit
        open fun packInt(value: Int): Unit
        open fun packIntBigger(value: Int): Unit
        open fun packLong(value: Long): Unit
        open fun packLongArray(array: LongArray, fromIndex: Int, toIndex: Int): Unit
        var pos: Int
        var sizeMask: Int
        open fun write(b: Int): Unit
        open fun write(b: ByteArray): Unit
        open fun write(b: ByteArray, off: Int, len: Int): Unit
        open fun writeBoolean(v: Boolean): Unit
        open fun writeByte(v: Int): Unit
        open fun writeBytes(s: String): Unit
        open fun writeChar(v: Int): Unit
        open fun writeChars(s: String): Unit
        open fun writeDouble(v: Double): Unit
        open fun writeFloat(v: Float): Unit
        open fun writeInt(v: Int): Unit
        open fun writeLong(v: Long): Unit
        open fun writeShort(v: Int): Unit
        open fun writeUTF(s: String): Unit
      class HTreeMap<K, V> : ConcurrentMap<K, V>, ConcurrencyAware, MapExtra<K, V>, Verifiable, Closeable
        Module Contents HTreeMap(keySerializer: Serializer<K>, valueSerializer: Serializer<V>, valueInline: Boolean, concShift: Int, dirShift: Int, levels: Int, stores: Array<Store>, indexTrees: Array<<ERROR CLASS>>, hashSeed: Int, counterRecids: LongArray?, expireCreateTTL: Long, expireUpdateTTL: Long, expireGetTTL: Long, expireMaxSize: Long, expireStoreSize: Long, expireCreateQueues: Array<QueueLong>?, expireUpdateQueues: Array<QueueLong>?, expireGetQueues: Array<QueueLong>?, expireExecutor: ScheduledExecutorService?, expireExecutorPeriod: Long, expireCompactThreshold: Double?, isThreadSafe: Boolean, valueLoader: (K) -> V?, modificationListeners: Array<MapModificationListener<K, V>>?, closeable: Closeable?, hasValues: Boolean = true)
        class KeySet<K> : AbstractSet<K>
          Module Contents KeySet(map: HTreeMap<K, Any?>)
          fun add(element: K): Boolean
          fun clear(): Unit
          fun isEmpty(): Boolean
          fun iterator(): MutableIterator<K?>
          val map: HTreeMap<K, Any?>
          fun remove(element: K): Boolean
          val size: Int
        protected val QUEUE_CREATE: Long
        protected val QUEUE_GET: Long
        protected val QUEUE_UPDATE: Long
        fun calculateCollisionSize(): <ERROR CLASS><Long, Long>
        fun checkThreadSafe(): Unit
        fun clear(): Unit
        protected fun clear(notifyListeners: Int = 1): Unit
        fun clear2(notifyListeners: Boolean = true): Unit
        fun clearWithExpire(): Unit
        fun clearWithoutNotification(): Unit
        fun close(): Unit
        val concShift: Int
        fun containsKey(key: K?): Boolean
        fun containsValue(value: V?): Boolean
        val counterRecids: LongArray?
        val dirShift: Int
        val entries: MutableSet<MutableEntry<K?, V?>>
        fun equals(other: Any?): Boolean
        val expireCompactThreshold: Double?
        val expireCreateQueues: Array<QueueLong>?
        val expireCreateTTL: Long
        fun expireEvict(): Unit
        protected fun expireEvictEntry(segment: Int, leafRecid: Long, nodeRecid: Long): Unit
        protected fun expireEvictSegment(segment: Int): Unit
        val expireExecutor: ScheduledExecutorService?
        val expireExecutorPeriod: Long
        val expireGetQueues: Array<QueueLong>?
        val expireGetTTL: Long
        protected fun expireId(nodeRecid: Long, queue: Long): Long
        val expireMaxSize: Long
        protected fun expireNodeRecidFor(expireId: Long): Long
        protected fun expireQueueFor(segment: Int, expireId: Long): QueueLong
        val expireStoreSize: Long
        val expireUpdateQueues: Array<QueueLong>?
        val expireUpdateTTL: Long
        fun forEach(action: BiConsumer<in K, in V>): Unit
        fun forEachKey(action: (K) -> Unit): Unit
        fun forEachValue(action: (V) -> Unit): Unit
        fun get(key: K?): V?
        protected fun getprotected(hash: Int, key: K, updateQueue: Boolean): V?
        val hasValues: Boolean
        protected fun hash(key: K): Int
        fun hashCode(): Int
        protected fun hashToIndex(hash: Int): Long
        protected fun hashToSegment(hash: Int): Int
        protected fun htreeEntry(key: K, valueOrig: V): MutableEntry<K?, V?>
        protected fun <E> htreeIterator(segment: Int, loadNext: (Any, Any) -> E): MutableIterator<E>
        val indexTrees: Array<<ERROR CLASS>>
        fun isClosed(): Boolean
        fun isEmpty(): Boolean
        val isForegroundEviction: Boolean
        val isThreadSafe: Boolean
        val keySerializer: Serializer<K>
        val keys: KeySet<K>
        protected fun leafGet(store: Store, leafRecid: Long): Array<Any>
        protected val leafSerializer: Serializer<Array<Any>>
        val levels: Int
        protected fun listenerNotify(key: K, oldValue: V?, newValue: V?, triggered: Boolean): Unit
        protected val locks: Array<ReadWriteLock?>
        fun <K, V> make(keySerializer: Serializer<K> = Serializer.ELSA as Serializer<K>, valueSerializer: Serializer<V> = Serializer.ELSA as Serializer<V>, valueInline: Boolean = false, concShift: Int = CC.HTREEMAP_CONC_SHIFT, dirShift: Int = CC.HTREEMAP_DIR_SHIFT, levels: Int = CC.HTREEMAP_LEVELS, stores: Array<Store> = Array(1.shl(concShift), {StoreTrivial()}), indexTrees: Array<<ERROR CLASS>> = Array(1.shl(concShift), { i->IndexTreeLongLongMap.make(stores[i], levels=levels, dirShift = dirShift)}), hashSeed: Int = SecureRandom().nextInt(), counterRecids: LongArray? = null, expireCreateTTL: Long = 0L, expireUpdateTTL: Long = 0L, expireGetTTL: Long = 0L, expireMaxSize: Long = 0L, expireStoreSize: Long = 0L, expireCreateQueues: Array<QueueLong>? = if(expireCreateTTL<=0L) null else Array(stores.size, { i->QueueLong.make(store = stores[i])}), expireUpdateQueues: Array<QueueLong>? = if(expireUpdateTTL<=0L) null else Array(stores.size, { i->QueueLong.make(store = stores[i])}), expireGetQueues: Array<QueueLong>? = if(expireGetTTL<=0L) null else Array(stores.size, { i->QueueLong.make(store = stores[i])}), expireExecutor: ScheduledExecutorService? = null, expireExecutorPeriod: Long = 0, expireCompactThreshold: Double? = null, isThreadSafe: Boolean = true, valueLoader: (K) -> V = null, modificationListeners: Array<MapModificationListener<K, V>>? = null, closeable: Closeable? = null): HTreeMap<K, V>
        fun put(key: K?, value: V?): V?
        fun putAll(from: Map<out K?, V?>): Unit
        fun putIfAbsent(key: K?, value: V?): V?
        fun putIfAbsentBoolean(key: K?, value: V?): Boolean
        protected fun putprotected(hash: Int, key: K, value: V, triggered: Boolean): V?
        fun remove(key: K?): V?
        fun remove(key: Any?, value: Any?): Boolean
        protected fun removeprotected(hash: Int, key: K, evicted: Boolean): V?
        fun replace(key: K?, oldValue: V?, newValue: V?): Boolean
        fun replace(key: K?, value: V?): V?
        val size: Int
        fun sizeLong(): Long
        val stores: Array<Store>
        val valueInline: Boolean
        val valueLoader: (K) -> V?
        val valueSerializer: Serializer<V>
        protected fun valueUnwrap(segment: Int, wrappedValue: Any): V
        protected fun valueWrap(segment: Int, value: V): Any
        val values: MutableCollection<V?>
        fun verify(): Unit
      class IndexTreeList<E> : AbstractList<E?>
        Module Contents IndexTreeList(store: Store, serializer: Serializer<E>, map: <ERROR CLASS>, counterRecid: Long, isThreadSafe: Boolean)
        fun add(element: E?): Boolean
        fun add(index: Int, element: E?): Unit
        fun checkIndex(index: Int): Unit
        fun clear(): Unit
        val counterRecid: Long
        fun get(index: Int): E?
        fun isEmpty(): Boolean
        val isThreadSafe: Boolean
        fun iterator(): MutableIterator<E?>
        val lock: ReentrantReadWriteLock?
        val map: <ERROR CLASS>
        fun removeAt(index: Int): E?
        val serializer: Serializer<E>
        fun set(index: Int, element: E?): E?
        var size: Int
        val store: Store
      class IndexTreeLongLongMap
        Module Contents IndexTreeLongLongMap(store: Store, rootRecid: Long, dirShift: Int, levels: Int, collapseOnRemove: Boolean)
        fun addToValue(key: Long, toBeAdded: Long): Long
        fun allSatisfy(predicate: <ERROR CLASS>): Boolean
        fun anySatisfy(predicate: <ERROR CLASS>): Boolean
        fun appendString(appendable: Appendable, start: String, separator: String, end: String): Unit
        fun asSynchronized(): <ERROR CLASS>?
        fun asUnmodifiable(): <ERROR CLASS>?
        fun clear(): Unit
        val collapseOnRemove: Boolean
        fun <V> collect(function: <ERROR CLASS><out V>): MutableCollection<V>?
        fun contains(value: Long): Boolean
        fun containsKey(key: Long): Boolean
        fun containsValue(value: Long): Boolean
        fun count(predicate: <ERROR CLASS>): Int
        fun detectIfNone(predicate: <ERROR CLASS>, ifNone: Long): Long
        val dirShift: Int
        fun each(procedure: <ERROR CLASS>): Unit
        fun equals(other: Any?): Boolean
        fun forEach(procedure: <ERROR CLASS>): Unit
        fun forEachKey(procedure: <ERROR CLASS>): Unit
        fun forEachKeyValue(procedure: <ERROR CLASS>): Unit
        fun forEachValue(procedure: <ERROR CLASS>): Unit
        fun get(key: Long): Long
        fun getIfAbsent(key: Long, ifAbsent: Long): Long
        fun getIfAbsentPut(key: Long, function: <ERROR CLASS>): Long
        fun getIfAbsentPut(key: Long, value: Long): Long
        fun <P> getIfAbsentPutWith(key: Long, function: <ERROR CLASS><in P>, parameter: P): Long
        fun getIfAbsentPutWithKey(key: Long, function: <ERROR CLASS>): Long
        fun getOrThrow(key: Long): Long
        fun hashCode(): Int
        fun <T> injectInto(injectedValue: T, function: <ERROR CLASS><in T, out T>?): T
        fun keySet(): <ERROR CLASS>
        fun keyValuesView(): <ERROR CLASS><<ERROR CLASS>>
        fun keysView(): <ERROR CLASS>
        val levels: Int
        fun longIterator(): <ERROR CLASS>
        fun make(store: Store = StoreTrivial(), rootRecid: Long = store.put(dirEmpty(), dirSer), dirShift: Int = CC.INDEX_TREE_LONGLONGMAP_DIR_SHIFT, levels: Int = CC.INDEX_TREE_LONGLONGMAP_LEVELS, collapseOnRemove: Boolean = true): IndexTreeLongLongMap
        fun max(): Long
        fun min(): Long
        fun noneSatisfy(predicate: <ERROR CLASS>): Boolean
        fun put(key: Long, value: Long): Unit
        fun putAll(map: <ERROR CLASS>): Unit
        fun reject(predicate: <ERROR CLASS>): <ERROR CLASS>?
        fun reject(predicate: <ERROR CLASS>): <ERROR CLASS>
        fun remove(key: Long): Unit
        fun removeKey(key: Long): Unit
        fun removeKeyIfAbsent(key: Long, value: Long): Long
        val rootRecid: Long
        fun select(predicate: <ERROR CLASS>): <ERROR CLASS>?
        fun select(predicate: <ERROR CLASS>): <ERROR CLASS>?
        fun size(): Int
        val store: Store
        fun sum(): Long
        fun toArray(): LongArray
        fun toImmutable(): <ERROR CLASS>
        fun toString(): String
        fun updateValue(key: Long, initialValueIfAbsent: Long, function: <ERROR CLASS>): Long
        fun values(): <ERROR CLASS>
        fun withKeyValue(key: Long, value: Long): <ERROR CLASS>?
        fun withoutAllKeys(keys: <ERROR CLASS>): <ERROR CLASS>?
        fun withoutKey(key: Long): <ERROR CLASS>?
      interface MapExtra<K, V> : ConcurrentMap<K, V>
        Module Contents abstract fun forEach(action: BiConsumer<in K, in V>): Unit
        abstract fun forEachKey(procedure: (K) -> Unit): Unit
        abstract fun forEachValue(procedure: (V) -> Unit): Unit
        abstract fun isClosed(): Boolean
        abstract val keySerializer: Serializer<K>
        abstract fun putIfAbsentBoolean(key: K?, value: V?): Boolean
        abstract fun sizeLong(): Long
        abstract val valueSerializer: Serializer<V>
      interface MapModificationListener<K : Any, V : Any>
        Module Contents abstract fun modify(key: K, oldValue: V, newValue: V, triggered: Boolean): Unit
      object Pump
        Module Contents abstract class Sink<E, R>
          Module Contents Sink()
          abstract fun create(): R
          abstract fun put(e: E): Unit
          fun putAll(i: Iterable<E>): Unit
          fun putAll(i: Iterator<E>): Unit
        fun <K, V> treeMap(store: Store, keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>, comparator: Comparator<K> = keySerializer, leafNodeSize: Int = CC.BTREEMAP_MAX_NODE_SIZE*3/4, dirNodeSize: Int = CC.BTREEMAP_MAX_NODE_SIZE*3/4): Sink<<ERROR CLASS><K, V>, Unit>
      class QueueLong : Verifiable
        Module Contents QueueLong(store: Store, tailRecid: Long, headRecid: Long, headPrevRecid: Long)
        data class Node
          Module Contents Node(prevRecid: Long, nextRecid: Long, timestamp: Long, value: Long)
          object SERIALIZER : Serializer<Node>
            Module Contents fun deserialize(input: DataInput2, available: Int): Node?
            fun serialize(out: DataOutput2, value: Node): Unit
          val nextRecid: Long
          val prevRecid: Long
          val timestamp: Long
          val value: Long
        fun bump(nodeRecid: Long, newTimestamp: Long): Unit
        fun clear(): Unit
        fun forEach(body: (Long, Long, Long) -> Unit): Unit
        var head: Long
        var headPrev: Long
        val headPrevRecid: Long
        val headRecid: Long
        fun make(store: Store = StoreTrivial(), tailRecid: Long = store.put(store.put(null, Node.SERIALIZER), Serializer.RECID), headRecid: Long = store.put(store.get(tailRecid, Serializer.RECID), Serializer.RECID), headPrevRecid: Long = store.put(0L, Serializer.RECID)): QueueLong
        fun printContent(out: PrintStream): Unit
        fun put(timestamp: Long, value: Long): Long
        fun put(timestamp: Long, value: Long, nodeRecid: Long): Unit
        fun remove(nodeRecid: Long, removeNode: Boolean): Node
        fun size(): Long
        val store: Store
        var tail: Long
        val tailRecid: Long
        fun take(): Node?
        fun takeUntil(f: QueueLongTakeUntil): Unit
        fun valuesArray(): LongArray
        fun verify(): Unit
      interface QueueLongTakeUntil
        Module Contents abstract fun take(nodeRecid: Long, node: Node): Boolean
      interface Serializer<A : Any> : Comparator<A>
        Module Contents static val BIG_DECIMAL: GroupSerializer<BigDecimal>
        static val BIG_INTEGER: GroupSerializer<BigInteger>
        static val BOOLEAN: GroupSerializer<Boolean>
        static val BYTE: GroupSerializer<Byte>
        static val BYTE_ARRAY: GroupSerializer<ByteArray>
        static val BYTE_ARRAY_DELTA: GroupSerializer<ByteArray>
        static val BYTE_ARRAY_DELTA2: GroupSerializer<ByteArray>
        static val BYTE_ARRAY_NOSIZE: Serializer<ByteArray>
        static val CHAR: GroupSerializer<Char>
        static val CHAR_ARRAY: GroupSerializer<CharArray>
        static val CLASS: GroupSerializer<Class<*>>
        static val DATE: GroupSerializer<Date>
        static val DOUBLE: GroupSerializer<Double>
        static val DOUBLE_ARRAY: GroupSerializer<DoubleArray>
        static val ELSA: GroupSerializer<Any>
        static val FLOAT: GroupSerializer<Float>
        static val FLOAT_ARRAY: GroupSerializer<FloatArray>
        static val ILLEGAL_ACCESS: GroupSerializer<Any>
        static val INTEGER: GroupSerializer<Int>
        static val INTEGER_DELTA: GroupSerializer<Int>
        static val INTEGER_PACKED: GroupSerializer<Int>
        static val INT_ARRAY: GroupSerializer<IntArray>
        static val JAVA: GroupSerializer<Any>
        static val LONG: GroupSerializer<Long>
        static val LONG_ARRAY: GroupSerializer<LongArray>
        static val LONG_DELTA: GroupSerializer<Long>
        static val LONG_PACKED: GroupSerializer<Long>
        static val RECID: GroupSerializer<Long>
        static val RECID_ARRAY: GroupSerializer<LongArray>
        static val SHORT: GroupSerializer<Short>
        static val SHORT_ARRAY: GroupSerializer<ShortArray>
        static val STRING: GroupSerializer<String>
        static val STRING_ASCII: GroupSerializer<String>
        static val STRING_DELTA: GroupSerializer<String>
        static val STRING_DELTA2: GroupSerializer<String>
        static val STRING_INTERN: GroupSerializer<String>
        static val STRING_NOSIZE: Serializer<String>
        static val STRING_ORIGHASH: GroupSerializer<String>
        static val UUID: GroupSerializer<UUID>
        open fun clone(value: A): A
        open fun compare(first: A, second: A): Int
        abstract fun deserialize(input: DataInput2, available: Int): A
        open fun deserializeFromLong(input: Long, available: Int): A
        open fun equals(first: A, second: A): Boolean
        open fun fixedSize(): Int
        open fun hashCode(o: A, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun needsAvailableSizeHint(): Boolean
        abstract fun serialize(out: DataOutput2, value: A): Unit
      class SortedTableMap<K, V> : ConcurrentMap<K, V>, ConcurrentNavigableMap<K, V>, ConcurrentNavigableMapExtra<K, V>
        Module Contents SortedTableMap(keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>, pageSize: Long, volume: Volume, hasValues: Boolean = false)
        class Maker<K, V>
          Module Contents Maker(_volume: Volume? = null, _keySerializer: GroupSerializer<K>? = null, _valueSerializer: GroupSerializer<V>? = null)
          protected val _keySerializer: GroupSerializer<K>?
          protected var _nodeSize: Int
          protected var _pageSize: Long
          protected val _valueSerializer: GroupSerializer<V>?
          protected val _volume: Volume?
          fun createFrom(pairs: Iterable<<ERROR CLASS><K, V>>): SortedTableMap<K, V>
          fun createFrom(map: Map<K, V>): SortedTableMap<K, V>
          fun createFromSink(): Sink<K, V>
          fun nodeSize(nodeSize: Int): Maker<K, V>
          fun pageSize(pageSize: Long): Maker<K, V>
        protected class NodeIterator
          Module Contents NodeIterator(map: SortedTableMap<*, *>, pageOffset: Long, pageWithHeadOffset: Long, pageNodeCount: Long, node: Long)
          fun keysOffset(): Long
          fun keysOffsetEnd(): Long
          fun keysSize(): Int
          fun loadKeys(): Array<Any>
          fun loadVals(keysSize: Int): Array<Any>
          fun moveToNext(): Boolean
          fun moveToPrev(): Boolean
          fun valsOffset(): Long
          fun valsOffsetEnd(): Long
        abstract class Sink<K, V> : Sink<<ERROR CLASS><K, V>, SortedTableMap<K, V>>
          Module Contents Sink()
          fun put(key: K, value: V): Unit
        fun ceilingEntry(key: K?): MutableEntry<K, V>?
        fun ceilingKey(key: K?): K?
        fun clear(): Unit
        fun close(): Unit
        val comparator: GroupSerializer<K>
        fun comparator(): Comparator<in K>?
        fun containsKey(key: K?): Boolean
        fun containsValue(value: V?): Boolean
        fun <K, V> create(volume: Volume, keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>): Maker<K, V>
        fun <K, V> createFromSink(keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>, volume: Volume, pageSize: Long = CC.PAGE_SIZE, nodeSize: Int = CC.BTREEMAP_MAX_NODE_SIZE): Sink<K, V>
        fun descendingEntryIterator(): MutableIterator<MutableEntry<K, V?>>
        fun descendingEntryIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<MutableEntry<K, V?>>
        fun descendingKeyIterator(): MutableIterator<K>
        fun descendingKeyIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<K>
        fun descendingKeySet(): NavigableSet<K>?
        fun descendingMap(): ConcurrentNavigableMap<K, V>
        protected fun descendingNodeIterator(): NodeIterator
        fun descendingValueIterator(): MutableIterator<V>
        fun descendingValueIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<V>
        val entries: MutableSet<MutableEntry<K, V>>
        fun entryIterator(): MutableIterator<MutableEntry<K, V>>
        fun entryIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<MutableEntry<K, V?>>
        fun equals(other: Any?): Boolean
        fun findHigher(key: K?, inclusive: Boolean): MutableEntry<K, V>?
        fun findHigherKey(key: K?, inclusive: Boolean): K?
        fun findLower(key: K?, inclusive: Boolean): MutableEntry<K, V>?
        fun findLowerKey(key: K?, inclusive: Boolean): K?
        fun firstEntry(): MutableEntry<K, V>?
        fun firstKey(): K
        fun firstKey2(): K?
        fun floorEntry(key: K?): MutableEntry<K, V>?
        fun floorKey(key: K?): K?
        fun forEach(action: BiConsumer<in K, in V>): Unit
        fun forEachKey(procedure: (K) -> Unit): Unit
        fun forEachValue(procedure: (V) -> Unit): Unit
        fun get(key: K?): V?
        val hasValues: Boolean
        fun headMap(toKey: K?, inclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun headMap(toKey: K): ConcurrentNavigableMap<K, V>
        fun higherEntry(key: K?): MutableEntry<K, V>?
        fun higherKey(key: K?): K?
        fun isClosed(): Boolean
        fun isEmpty(): Boolean
        fun keyIterator(): MutableIterator<K>
        fun keyIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<K>
        val keySerializer: GroupSerializer<K>
        val keys: NavigableSet<K>
        fun lastEntry(): MutableEntry<K, V>?
        fun lastKey(): K
        fun lastKey2(): K?
        fun lowerEntry(key: K?): MutableEntry<K, V>?
        fun lowerKey(key: K?): K?
        fun navigableKeySet(): NavigableSet<K>?
        protected fun nodeIterator(): NodeIterator
        protected fun nodeIterator(lo: K): NodeIterator
        protected fun nodeSearch(key: K, offset: Long, offsetWithHead: Long, nodeCount: Int): Int
        fun <K, V> open(volume: Volume, keySerializer: GroupSerializer<K>, valueSerializer: GroupSerializer<V>): SortedTableMap<K, V>
        val pageCount: Long
        protected val pageKeys: Any
        val pageSize: Long
        fun pollFirstEntry(): MutableEntry<K, V>?
        fun pollLastEntry(): MutableEntry<K, V>?
        fun put(key: K?, value: V?): V?
        fun putAll(from: Map<out K?, V?>): Unit
        fun putIfAbsent(key: K?, value: V?): V?
        fun putIfAbsentBoolean(key: K?, value: V?): Boolean
        fun remove(key: K?): V?
        fun remove(key: Any?, value: Any?): Boolean
        fun replace(key: K?, oldValue: V?, newValue: V?): Boolean
        fun replace(key: K?, value: V?): V?
        val size: Int
        val sizeLong: Long
        fun sizeLong(): Long
        fun subMap(fromKey: K?, fromInclusive: Boolean, toKey: K?, toInclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun subMap(fromKey: K, toKey: K): ConcurrentNavigableMap<K, V>
        fun tailMap(fromKey: K?, inclusive: Boolean): ConcurrentNavigableMap<K, V>
        fun tailMap(fromKey: K): ConcurrentNavigableMap<K, V>
        fun valueIterator(): MutableIterator<V>
        fun valueIterator(lo: K?, loInclusive: Boolean, hi: K?, hiInclusive: Boolean): MutableIterator<V>
        val valueSerializer: GroupSerializer<V>
        val values: MutableCollection<V>
        protected val volume: Volume
      interface Store : StoreImmutable, Verifiable, ConcurrencyAware
        Module Contents abstract fun close(): Unit
        abstract fun commit(): Unit
        abstract fun compact(): Unit
        abstract fun <R> compareAndSwap(recid: Long, expectedOldRecord: R?, newRecord: R?, serializer: Serializer<R>): Boolean
        abstract fun <R> delete(recid: Long, serializer: Serializer<R>): Unit
        abstract fun fileLoad(): Boolean
        abstract val isClosed: Boolean
        abstract val isReadOnly: Boolean
        abstract fun preallocate(): Long
        abstract fun <R> put(record: R?, serializer: Serializer<R>): Long
        abstract fun <R> update(recid: Long, record: R?, serializer: Serializer<R>): Unit
        abstract fun verify(): Unit
      interface StoreBinary : Store
        Module Contents abstract fun getBinaryLong(recid: Long, f: StoreBinaryGetLong): Long
      interface StoreBinaryGetLong
        Module Contents abstract fun get(input: DataInput2, size: Int): Long
      class StoreDirect : StoreDirectAbstract, StoreBinary
        Module Contents StoreDirect(file: String?, volumeFactory: VolumeFactory, isReadOnly: Boolean, fileLockWait: Long, isThreadSafe: Boolean, concShift: Int, allocateIncrement: Long, allocateStartSize: Long, fileDeleteAfterClose: Boolean, fileDeleteAfterOpen: Boolean, checksum: Boolean, checksumHeader: Boolean, checksumHeaderBypass: Boolean)
        protected fun allocateNewIndexPage(): Long
        protected fun allocateNewPage(): Long
        protected fun calculateFreeSize(): Long
        fun close(): Unit
        fun commit(): Unit
        fun compact(): Unit
        fun <R> compareAndSwap(recid: Long, expectedOldRecord: R?, newRecord: R?, serializer: Serializer<R>): Boolean
        fun <R> delete(recid: Long, serializer: Serializer<R>): Unit
        fun fileLoad(): Boolean
        protected val freeSize: AtomicLong
        protected fun freeSizeIncrement(increment: Long): Unit
        fun <R> get(recid: Long, serializer: Serializer<R>): R?
        fun getAllFiles(): Iterable<String>
        fun getAllRecids(): LongIterator
        fun getBinaryLong(recid: Long, f: StoreBinaryGetLong): Long
        fun getFreeSize(): Long
        protected fun getIndexVal(recid: Long): Long
        fun getTotalSize(): Long
        protected val headVol: Volume
        val isReadOnly: Boolean
        protected fun linkedRecordDelete(indexValue: Long): Unit
        protected fun linkedRecordGet(indexValue: Long): ByteArray
        protected fun linkedRecordPut(output: ByteArray, size: Int): Long
        protected fun longStackFindEnd(pageOffset: Long, pos: Long): Long
        protected fun longStackForEach(masterLinkOffset: Long, body: (Long) -> Unit): Unit
        protected fun longStackNewChunk(masterLinkOffset: Long, prevPageOffset: Long, value: Long, valueSize: Long, recursive: Boolean): Unit
        protected fun longStackPut(masterLinkOffset: Long, value: Long, recursive: Boolean): Unit
        protected fun longStackTake(masterLinkOffset: Long, recursive: Boolean): Long
        fun make(file: String? = null, volumeFactory: VolumeFactory = if(file==null) CC.DEFAULT_MEMORY_VOLUME_FACTORY else CC.DEFAULT_FILE_VOLUME_FACTORY, fileLockWait: Long = 0L, isReadOnly: Boolean = false, isThreadSafe: Boolean = true, concShift: Int = CC.STORE_DIRECT_CONC_SHIFT, allocateIncrement: Long = CC.PAGE_SIZE, allocateStartSize: Long = 0L, fileDeleteAfterClose: Boolean = false, fileDeleteAfterOpen: Boolean = false, checksum: Boolean = false, checksumHeader: Boolean = true, checksumHeaderBypass: Boolean = false): StoreDirect
        fun preallocate(): Long
        fun <R> put(record: R?, serializer: Serializer<R>): Long
        protected fun setIndexVal(recid: Long, value: Long): Unit
        fun <R> update(recid: Long, record: R?, serializer: Serializer<R>): Unit
        fun verify(): Unit
        protected val volume: Volume
      abstract class StoreDirectAbstract : Store
        Module Contents StoreDirectAbstract(file: String?, volumeFactory: VolumeFactory, isThreadSafe: Boolean, concShift: Int, fileDeleteAfterClose: Boolean, checksum: Boolean, checksumHeader: Boolean, checksumHeaderBypass: Boolean)
        protected fun allocateData(size: Int, recursive: Boolean): Long
        protected abstract fun allocateNewIndexPage(): Long
        protected abstract fun allocateNewPage(): Long
        protected fun allocateRecid(): Long
        protected fun assertNotClosed(): Unit
        fun calculateChecksum(): Long
        fun calculateHeaderChecksum(): Int
        val checksum: Boolean
        val checksumHeader: Boolean
        val checksumHeaderBypass: Boolean
        protected val closed: AtomicBoolean
        val concShift: Int
        protected var dataTail: Long
        protected fun <R> deserialize(serializer: Serializer<R>, di: DataInput2, size: Long): R?
        val file: String?
        val fileDeleteAfterClose: Boolean
        protected fun fileHeaderCheck(): Unit
        protected fun fileHeaderCompose(): Long
        protected abstract fun freeSizeIncrement(increment: Long): Unit
        protected abstract fun getIndexVal(recid: Long): Long
        protected abstract val headVol: Volume
        protected val indexPages: <ERROR CLASS>
        protected fun indexValCompose(size: Long, offset: Long, linked: Int, unused: Int, archive: Int): Long
        protected fun indexValFlagArchive(indexValue: Long): Boolean
        protected fun indexValFlagLinked(indexValue: Long): Boolean
        protected fun indexValFlagUnused(indexValue: Long): Boolean
        open val isClosed: Boolean
        open val isThreadSafe: Boolean
        protected fun loadIndexPages(indexPages: <ERROR CLASS>): Unit
        protected val locks: Array<ReadWriteLock?>
        protected fun longStackMasterLinkOffset(size: Long): Long
        protected abstract fun longStackPut(masterLinkOffset: Long, value: Long, recursive: Boolean): Unit
        protected abstract fun longStackTake(masterLinkOffset: Long, recursive: Boolean): Long
        protected var maxRecid: Long
        protected fun recidToOffset(recid2: Long): Long
        protected fun recidToSegment(recid: Long): Int
        protected fun releaseData(size: Long, offset: Long, recursive: Boolean): Unit
        protected fun releaseRecid(recid: Long): Unit
        protected val segmentCount: Int
        protected val segmentMask: Long
        protected fun <R> serialize(record: R?, serializer: Serializer<R>): DataOutput2?
        protected abstract fun setIndexVal(recid: Long, value: Long): Unit
        fun storeHeaderCompose(): Int
        protected val structuralLock: Lock?
        protected abstract val volume: Volume
        protected val volumeExistsAtStart: Boolean
        val volumeFactory: VolumeFactory
      interface StoreImmutable
        Module Contents abstract fun <R> get(recid: Long, serializer: Serializer<R>): R?
        abstract fun getAllFiles(): Iterable<String>
        abstract fun getAllRecids(): LongIterator
      class StoreOnHeap : Store
        Module Contents StoreOnHeap(isThreadSafe: Boolean = true)
        fun close(): Unit
        fun commit(): Unit
        fun compact(): Unit
        fun <R> compareAndSwap(recid: Long, expectedOldRecord: R?, newRecord: R?, serializer: Serializer<R>): Boolean
        fun <R> delete(recid: Long, serializer: Serializer<R>): Unit
        fun fileLoad(): Boolean
        fun <R> get(recid: Long, serializer: Serializer<R>): R?
        fun getAllFiles(): Iterable<String>
        fun getAllRecids(): LongIterator
        val isClosed: Boolean
        val isReadOnly: Boolean
        val isThreadSafe: Boolean
        fun preallocate(): Long
        fun <R> put(record: R?, serializer: Serializer<R>): Long
        fun <R> update(recid: Long, record: R?, serializer: Serializer<R>): Unit
        fun verify(): Unit
      class StoreReadOnlyWrapper : Store
        Module Contents StoreReadOnlyWrapper(store: Store)
        fun close(): Unit
        fun commit(): Unit
        fun compact(): Unit
        fun <R> compareAndSwap(recid: Long, expectedOldRecord: R?, newRecord: R?, serializer: Serializer<R>): Boolean
        fun <R> delete(recid: Long, serializer: Serializer<R>): Unit
        fun fileLoad(): Boolean
        fun <R> get(recid: Long, serializer: Serializer<R>): R?
        fun getAllFiles(): Iterable<String>
        fun getAllRecids(): LongIterator
        val isClosed: Boolean
        val isReadOnly: Boolean
        val isThreadSafe: Boolean
        fun preallocate(): Long
        fun <R> put(record: R?, serializer: Serializer<R>): Long
        protected val store: Store
        fun <R> update(recid: Long, record: R?, serializer: Serializer<R>): Unit
        fun verify(): Unit
      open class StoreTrivial : Store
        Module Contents StoreTrivial(isThreadSafe: Boolean = true)
        fun clear(): Unit
        open fun close(): Unit
        open fun commit(): Unit
        open fun compact(): Unit
        open fun <R> compareAndSwap(recid: Long, expectedOldRecord: R?, newRecord: R?, serializer: Serializer<R>): Boolean
        open fun <R> delete(recid: Long, serializer: Serializer<R>): Unit
        open fun equals(other: Any?): Boolean
        protected fun fileHeaderCheck(header: Long): Unit
        protected fun fileHeaderCompose(): Long
        open fun fileLoad(): Boolean
        open fun <R> get(recid: Long, serializer: Serializer<R>): R?
        open fun getAllFiles(): Iterable<String>
        open fun getAllRecids(): LongIterator
        open val isClosed: Boolean
        open val isReadOnly: Boolean
        open val isThreadSafe: Boolean
        fun loadFrom(inStream: InputStream): Unit
        protected fun loadFromInternal(inStream: InputStream): Unit
        protected val lock: ReadWriteLock?
        open fun preallocate(): Long
        open fun <R> put(record: R?, serializer: Serializer<R>): Long
        fun saveTo(outStream: OutputStream): Unit
        open fun <R> update(recid: Long, record: R?, serializer: Serializer<R>): Unit
        open fun verify(): Unit
      class StoreTrivialTx : StoreTrivial, StoreTx
        Module Contents StoreTrivialTx(file: File, isThreadSafe: Boolean = true, deleteFilesAfterClose: Boolean = false)
        fun close(): Unit
        fun commit(): Unit
        val deleteFilesAfterClose: Boolean
        val file: File
        fun getAllFiles(): Iterable<String>
        protected fun loadFrom(number: Long): Unit
        val path: Path
        fun rollback(): Unit
      interface StoreTx : Store
        Module Contents abstract fun rollback(): Unit
      class StoreWAL : StoreDirectAbstract, StoreTx
        Module Contents StoreWAL(file: String?, volumeFactory: VolumeFactory, fileLockWait: Long, isThreadSafe: Boolean, concShift: Int, allocateIncrement: Long, allocateStartSize: Long, fileDeleteAfterClose: Boolean, fileDeleteAfterOpen: Boolean, checksum: Boolean, checksumHeader: Boolean, checksumHeaderBypass: Boolean)
        protected val TOMB1: Long
        protected fun allocateNewIndexPage(): Long
        protected fun allocateNewPage(): Long
        protected val allocatedPages: <ERROR CLASS>
        protected val cacheIndexLinks: <ERROR CLASS>
        protected val cacheIndexVals: <ERROR CLASS>
        protected val cacheRecords: <ERROR CLASS>
        protected val cacheStacks: <ERROR CLASS>
        fun close(): Unit
        fun commit(): Unit
        fun compact(): Unit
        fun <R> compareAndSwap(recid: Long, expectedOldRecord: R?, newRecord: R?, serializer: Serializer<R>): Boolean
        fun <R> delete(recid: Long, serializer: Serializer<R>): Unit
        fun fileLoad(): Boolean
        protected fun freeSizeIncrement(increment: Long): Unit
        fun <R> get(recid: Long, serializer: Serializer<R>): R?
        fun getAllFiles(): Iterable<String>
        fun getAllRecids(): LongIterator
        protected fun getIndexVal(recid: Long): Long
        protected val headBytes: ByteArray
        protected val headVol: SingleByteArrayVol
        protected var indexPagesBackup: LongArray
        val isReadOnly: Boolean
        protected fun linkedRecordDelete(indexValue: Long, recid: Long): Unit
        protected fun linkedRecordGet(indexValue: Long, recid: Long): ByteArray
        protected fun linkedRecordPut(output: ByteArray, size: Int, recid: Long): Long
        protected fun longStackFindEnd(pageOffset: Long, pos: Long): Long
        protected fun longStackNewChunk(masterLinkOffset: Long, prevPageOffset: Long, value: Long, valueSize: Long, recursive: Boolean): Unit
        protected fun longStackPut(masterLinkOffset: Long, value: Long, recursive: Boolean): Unit
        protected fun longStackTake(masterLinkOffset: Long, recursive: Boolean): Long
        fun make(file: String? = null, volumeFactory: VolumeFactory = if(file==null) CC.DEFAULT_MEMORY_VOLUME_FACTORY else CC.DEFAULT_FILE_VOLUME_FACTORY, fileLockWait: Long = 0L, isThreadSafe: Boolean = true, concShift: Int = CC.STORE_DIRECT_CONC_SHIFT, allocateIncrement: Long = CC.PAGE_SIZE, allocateStartSize: Long = 0L, fileDeleteAfterClose: Boolean = false, fileDelteAfterOpen: Boolean = false, checksum: Boolean = false, checksumHeader: Boolean = true, checksumHeaderBypass: Boolean = false): StoreWAL
        fun preallocate(): Long
        fun <R> put(record: R?, serializer: Serializer<R>): Long
        protected val realVolume: Volume
        fun rollback(): Unit
        protected fun setIndexVal(recid: Long, value: Long): Unit
        fun <R> update(recid: Long, record: R?, serializer: Serializer<R>): Unit
        fun verify(): Unit
        protected val volume: Volume
        protected val wal: WriteAheadLog
      interface Verifiable
        Module Contents abstract fun verify(): Unit
      open class WriteAheadLog
        Module Contents WriteAheadLog(fileName: String, volumeFactory: VolumeFactory, featureBitMap: Long, fileDeleteAfterOpen: Boolean)
        WriteAheadLog(fileName: String)
        static val NOREPLAY: WALReplay
        interface WALReplay
          Module Contents abstract fun afterReplayFinished(): Unit
          abstract fun beforeReplayStart(): Unit
          abstract fun commit(): Unit
          abstract fun rollback(): Unit
          abstract fun writeByteArray(offset: Long, walId: Long, vol: Volume, volOffset: Long, length: Int): Unit
          abstract fun writeLong(offset: Long, value: Long): Unit
          abstract fun writePreallocate(recid: Long): Unit
          abstract fun writeRecord(recid: Long, walId: Long, vol: Volume, volOffset: Long, length: Int): Unit
          abstract fun writeTombstone(recid: Long): Unit
        open fun close(): Unit
        open fun commit(): Unit
        open fun destroyWalFiles(): Unit
        open fun fileLoad(): Boolean
        open fun getAllFiles(): MutableIterable<String>
        open fun getNumberOfFiles(): Long
        open fun initFailedCloseFiles(): Unit
        open fun replayWAL(replay: WALReplay): Unit
        open fun rollback(): Unit
        open fun seal(): Unit
        open fun startNextFile(): Unit
        open fun sync(): Unit
        open fun walGetByteArray(walPointer: Long): DataInput2
        open fun walGetByteArray2(walPointer: Long): ByteArray
        open fun walGetRecord(walPointer: Long, expectedRecid: Long): ByteArray
        open fun walPutByteArray(offset: Long, buf: ByteArray, bufPos: Int, size: Int): Long
        open fun walPutLong(offset: Long, value: Long): Unit
        open fun walPutPreallocate(recid: Long): Unit
        open fun walPutRecord(recid: Long, buf: ByteArray, bufPos: Int, size: Int): Long
        open fun walPutTombstone(recid: Long): Unit
    package org.mapdb.serializer
      Module Contents interface GroupSerializer<A : Any> : Serializer<A>
        Module Contents open fun nextValue(value: A): A
        open fun valueArrayBinaryGet(input: DataInput2, keysLen: Int, pos: Int): A
        open fun valueArrayBinarySearch(key: A, input: DataInput2, keysLen: Int, comparator: Comparator<Any>): Int
        abstract fun valueArrayCopyOfRange(vals: Any, from: Int, to: Int): Any
        abstract fun valueArrayDeleteValue(vals: Any, pos: Int): Any
        abstract fun valueArrayDeserialize(in: DataInput2, size: Int): Any
        abstract fun valueArrayEmpty(): Any
        abstract fun valueArrayFromArray(objects: Array<Any>): Any
        abstract fun valueArrayGet(vals: Any, pos: Int): A
        abstract fun valueArrayPut(vals: Any, pos: Int, newValue: A): Any
        abstract fun valueArraySearch(keys: Any, key: A): Int
        abstract fun valueArraySearch(keys: Any, key: A, comparator: Comparator<Any>): Int
        abstract fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
        abstract fun valueArraySize(vals: Any): Int
        open fun valueArrayToArray(vals: Any): Array<Any>
        abstract fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: A): Any
      abstract class GroupSerializerObjectArray<A : Any> : GroupSerializer<A>
        Module Contents GroupSerializerObjectArray()
        open fun valueArrayCopyOfRange(vals: Any, from: Int, to: Int): Array<Any>
        open fun valueArrayDeleteValue(vals: Any, pos: Int): Array<Any>
        open fun valueArrayDeserialize(in: DataInput2, size: Int): Array<Any>
        open fun valueArrayEmpty(): Array<Any>
        open fun valueArrayFromArray(objects: Array<Any>): Array<Any>
        open fun valueArrayGet(vals: Any, pos: Int): A
        open fun valueArrayPut(vals: Any, pos: Int, newValue: A): Array<Any>
        open fun valueArraySearch(keys: Any, key: A): Int
        open fun valueArraySearch(keys: Any, key: A, comparator: Comparator<Any>): Int
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
        open fun valueArraySize(vals: Any): Int
        open fun valueArrayToArray(vals: Any): Array<Any>
        open fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: A): Array<Any>
      open class SerializerArray<T : Any> : GroupSerializerObjectArray<Array<T>>
        Module Contents SerializerArray(serializer: Serializer<T>)
        SerializerArray(serializer: Serializer<T>, componentType: Class<T>)
        open fun compare(o1: Array<Any>, o2: Array<Any>): Int
        open fun deserialize(in: DataInput2, available: Int): Array<T>
        open fun equals(a1: Array<T>, a2: Array<T>): Boolean
        open fun equals(other: Any?): Boolean
        open fun hashCode(objects: Array<T>, seed: Int): Int
        open fun hashCode(): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: Array<T>): Unit
      open class SerializerArrayDelta<T : Any> : SerializerArray<T>
        Module Contents SerializerArrayDelta(serializer: Serializer<T>)
        open fun valueArrayDeserialize(in: DataInput2, size: Int): Array<Any>
        open fun valueArraySerialize(out: DataOutput2, vals2: Any): Unit
      open class SerializerArrayTuple : GroupSerializer<Array<Any>>
        Module Contents SerializerArrayTuple(serializers: Array<Serializer<Any>>, comparators: Array<Comparator<Any>>)
        SerializerArrayTuple(vararg serializers: Serializer<Any>)
        open fun compare(o1: Array<Any>, o2: Array<Any>): Int
        open fun deserialize(input: DataInput2, available: Int): Array<Any>
        open fun equals(a1: Array<Any>, a2: Array<Any>): Boolean
        open fun hashCode(objects: Array<Any>, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun nextValue(value: Array<Any>): Array<Any>
        open fun serialize(out: DataOutput2, value: Array<Any>): Unit
        open fun valueArrayCopyOfRange(vals: Any, from: Int, to: Int): Any
        open fun valueArrayDeleteValue(vals0: Any, pos: Int): Any
        open fun valueArrayDeserialize(in: DataInput2, size: Int): Any
        open fun valueArrayEmpty(): Any
        open fun valueArrayFromArray(objects: Array<Any>): Any
        open fun valueArrayGet(vals: Any, pos: Int): Array<Any>
        open fun valueArrayPut(vals: Any, pos: Int, newValue: Array<Any>): Any
        open fun valueArraySearch(keys: Any, key: Array<Any>): Int
        open fun valueArraySearch(keys: Any, key: Array<Any>, comparator: Comparator<Any>): Int
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
        open fun valueArraySize(vals: Any): Int
        open fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: Array<Any>): Any
      open class SerializerBigDecimal : GroupSerializerObjectArray<BigDecimal>
        Module Contents SerializerBigDecimal()
        open fun deserialize(in: DataInput2, available: Int): BigDecimal
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: BigDecimal): Unit
      open class SerializerBigInteger : GroupSerializerObjectArray<BigInteger>
        Module Contents SerializerBigInteger()
        open fun deserialize(in: DataInput2, available: Int): BigInteger
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: BigInteger): Unit
      open class SerializerBoolean : GroupSerializer<Boolean>
        Module Contents SerializerBoolean()
        open fun deserialize(in: DataInput2, available: Int): Boolean
        open fun fixedSize(): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: Boolean): Unit
        open fun valueArrayCopyOfRange(vals: Any, from: Int, to: Int): Any
        open fun valueArrayDeleteValue(vals: Any, pos: Int): Any
        open fun valueArrayDeserialize(in: DataInput2, size: Int): Any
        open fun valueArrayEmpty(): Any
        open fun valueArrayFromArray(objects: Array<Any>): Any
        open fun valueArrayGet(vals: Any, pos: Int): Boolean
        open fun valueArrayPut(vals: Any, pos: Int, newValue: Boolean): Any
        open fun valueArraySearch(keys: Any, key: Boolean): Int
        open fun valueArraySearch(keys: Any, key: Boolean, comparator: Comparator<Any>): Int
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
        open fun valueArraySize(vals: Any): Int
        open fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: Boolean): Any
      open class SerializerByte : GroupSerializerObjectArray<Byte>
        Module Contents SerializerByte()
        open fun deserialize(in: DataInput2, available: Int): Byte
        open fun fixedSize(): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: Byte): Unit
      open class SerializerByteArray : GroupSerializer<ByteArray>
        Module Contents SerializerByteArray()
        open fun compare(o1: ByteArray, o2: ByteArray): Int
        open fun deserialize(in: DataInput2, available: Int): ByteArray
        open fun equals(a1: ByteArray, a2: ByteArray): Boolean
        open fun hashCode(bytes: ByteArray, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun nextValue(value: ByteArray): ByteArray
        open fun serialize(out: DataOutput2, value: ByteArray): Unit
        open fun valueArrayCopyOfRange(vals: Any, from: Int, to: Int): Array<ByteArray>
        open fun valueArrayDeleteValue(vals: Any, pos: Int): Array<ByteArray>
        open fun valueArrayDeserialize(in: DataInput2, size: Int): Array<ByteArray>
        open fun valueArrayEmpty(): Array<ByteArray>
        open fun valueArrayFromArray(objects: Array<Any>): Array<ByteArray>
        open fun valueArrayGet(vals: Any, pos: Int): ByteArray
        open fun valueArrayPut(vals: Any, pos: Int, newValue: ByteArray): Array<ByteArray>
        open fun valueArraySearch(keys: Any, key: ByteArray): Int
        open fun valueArraySearch(keys: Any, key: ByteArray, comparator: Comparator<Any>): Int
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
        open fun valueArraySize(vals: Any): Int
        open fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: ByteArray): Array<ByteArray>
      open class SerializerByteArrayDelta : SerializerByteArray
        Module Contents SerializerByteArrayDelta()
        open fun valueArrayDeserialize(in: DataInput2, size: Int): Array<ByteArray>
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
      open class SerializerByteArrayDelta2 : GroupSerializer<ByteArray>
        Module Contents SerializerByteArrayDelta2()
        open fun compare(o1: ByteArray, o2: ByteArray): Int
        open fun deserialize(input: DataInput2, available: Int): ByteArray
        open fun equals(a1: ByteArray, a2: ByteArray): Boolean
        open fun hashCode(bytes: ByteArray, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: ByteArray): Unit
        open fun valueArrayCopyOfRange(keys: Any, from: Int, to: Int): ByteArrayKeys
        open fun valueArrayDeleteValue(keys: Any, pos: Int): ByteArrayKeys
        open fun valueArrayDeserialize(in: DataInput2, size: Int): ByteArrayKeys
        open fun valueArrayEmpty(): ByteArrayKeys
        open fun valueArrayFromArray(keys: Array<Any>): ByteArrayKeys
        open fun valueArrayGet(keys: Any, pos: Int): ByteArray
        open fun valueArrayPut(keys: Any, pos: Int, newValue: ByteArray): ByteArrayKeys
        open fun valueArraySearch(keys: Any, key: ByteArray): Int
        open fun valueArraySearch(keys: Any, key: ByteArray, comparator: Comparator<Any>): Int
        open fun valueArraySerialize(out: DataOutput2, keys2: Any): Unit
        open fun valueArraySize(keys: Any): Int
        open fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: ByteArray): ByteArrayKeys
      open class SerializerByteArrayNoSize : Serializer<ByteArray>
        Module Contents SerializerByteArrayNoSize()
        open fun compare(o1: ByteArray, o2: ByteArray): Int
        open fun deserialize(in: DataInput2, available: Int): ByteArray
        open fun equals(a1: ByteArray, a2: ByteArray): Boolean
        open fun hashCode(bytes: ByteArray, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun needsAvailableSizeHint(): Boolean
        open fun serialize(out: DataOutput2, value: ByteArray): Unit
      open class SerializerChar : GroupSerializerObjectArray<Char>
        Module Contents SerializerChar()
        open fun deserialize(in: DataInput2, available: Int): Char
        open fun fixedSize(): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: Char): Unit
      open class SerializerCharArray : GroupSerializerObjectArray<CharArray>
        Module Contents SerializerCharArray()
        open fun compare(o1: CharArray, o2: CharArray): Int
        open fun deserialize(in: DataInput2, available: Int): CharArray
        open fun equals(a1: CharArray, a2: CharArray): Boolean
        open fun hashCode(chars: CharArray, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun nextValue(value: CharArray): CharArray
        open fun serialize(out: DataOutput2, value: CharArray): Unit
      open class SerializerClass : GroupSerializerObjectArray<Class<*>>
        Module Contents SerializerClass(classLoader: ClassLoader)
        SerializerClass()
        open fun deserialize(in: DataInput2, available: Int): Class<*>
        open fun equals(a1: Class<*>, a2: Class<*>): Boolean
        open fun hashCode(aClass: Class<*>, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: Class<*>): Unit
      class SerializerCompressionDeflateWrapper<E : Any> : GroupSerializer<E>, Serializable
        Module Contents SerializerCompressionDeflateWrapper(serializer: GroupSerializer<E>)
        SerializerCompressionDeflateWrapper(serializer: GroupSerializer<E>, compressLevel: Int, dictionary: ByteArray)
        fun compare(o1: E, o2: E): Int
        fun deserialize(in: DataInput2, available: Int): E
        fun equals(other: Any?): Boolean
        fun equals(a1: E, a2: E): Boolean
        fun hashCode(): Int
        fun hashCode(e: E, seed: Int): Int
        fun isTrusted(): Boolean
        fun serialize(out: DataOutput2, value: E): Unit
        fun valueArrayCopyOfRange(vals: Any, from: Int, to: Int): Any
        fun valueArrayDeleteValue(vals: Any, pos: Int): Any
        fun valueArrayDeserialize(in: DataInput2, size: Int): Any
        fun valueArrayEmpty(): Any
        fun valueArrayFromArray(objects: Array<Any>): Any
        fun valueArrayGet(vals: Any, pos: Int): E
        fun valueArrayPut(vals: Any, pos: Int, newValue: E): Any
        fun valueArraySearch(keys: Any, key: E): Int
        fun valueArraySearch(keys: Any, key: E, comparator: Comparator<Any>): Int
        fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
        fun valueArraySize(vals: Any): Int
        fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: E): Any
      class SerializerCompressionWrapper<E : Any> : GroupSerializer<E>, Serializable
        Module Contents SerializerCompressionWrapper(serializer: GroupSerializer<E>)
        fun compare(o1: E, o2: E): Int
        fun deserialize(in: DataInput2, available: Int): E
        fun equals(other: Any?): Boolean
        fun equals(a1: E, a2: E): Boolean
        fun hashCode(): Int
        fun hashCode(e: E, seed: Int): Int
        fun isTrusted(): Boolean
        fun serialize(out: DataOutput2, value: E): Unit
        fun valueArrayCopyOfRange(vals: Any, from: Int, to: Int): Any
        fun valueArrayDeleteValue(vals: Any, pos: Int): Any
        fun valueArrayDeserialize(in: DataInput2, size: Int): Any
        fun valueArrayEmpty(): Any
        fun valueArrayFromArray(objects: Array<Any>): Any
        fun valueArrayGet(vals: Any, pos: Int): E
        fun valueArrayPut(vals: Any, pos: Int, newValue: E): Any
        fun valueArraySearch(keys: Any, key: E): Int
        fun valueArraySearch(keys: Any, key: E, comparator: Comparator<Any>): Int
        fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
        fun valueArraySize(vals: Any): Int
        fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: E): Any
      open class SerializerDate : SerializerEightByte<Date>
        Module Contents SerializerDate()
        open fun deserialize(in: DataInput2, available: Int): Date
        open fun serialize(out: DataOutput2, value: Date): Unit
        fun valueArraySearch(keys: Any, key: Date): Int
      open class SerializerDouble : SerializerEightByte<Double>
        Module Contents SerializerDouble()
        open fun deserialize(in: DataInput2, available: Int): Double
        open fun serialize(out: DataOutput2, value: Double): Unit
        open fun valueArraySearch(keys: Any, key: Double): Int
      open class SerializerDoubleArray : GroupSerializerObjectArray<DoubleArray>
        Module Contents SerializerDoubleArray()
        open fun compare(o1: DoubleArray, o2: DoubleArray): Int
        open fun deserialize(in: DataInput2, available: Int): DoubleArray
        open fun equals(a1: DoubleArray, a2: DoubleArray): Boolean
        open fun hashCode(bytes: DoubleArray, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: DoubleArray): Unit
      abstract class SerializerEightByte<E : Any> : GroupSerializer<E>
        Module Contents SerializerEightByte()
        open fun fixedSize(): Int
        open fun isTrusted(): Boolean
        open fun valueArrayBinaryGet(input: DataInput2, keysLen: Int, pos: Int): E
        open fun valueArrayCopyOfRange(vals: Any, from: Int, to: Int): Any
        open fun valueArrayDeleteValue(vals: Any, pos: Int): Any
        open fun valueArrayDeserialize(in: DataInput2, size: Int): Any
        open fun valueArrayEmpty(): Any
        open fun valueArrayFromArray(objects: Array<Any>): Any
        open fun valueArrayGet(vals: Any, pos: Int): E
        open fun valueArrayPut(vals: Any, pos: Int, newValue: E): Any
        fun valueArraySearch(keys: Any, key: E, comparator: Comparator<Any>): Int
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
        open fun valueArraySize(vals: Any): Int
        open fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: E): Any
      class SerializerElsa : GroupSerializerObjectArray<Any?>
        Module Contents SerializerElsa()
        fun deserialize(input: DataInput2, available: Int): Any?
        protected val ser: <ERROR CLASS>
        fun serialize(out: DataOutput2, value: Any): Unit
      open class SerializerFloat : SerializerFourByte<Float>
        Module Contents SerializerFloat()
        open fun deserialize(in: DataInput2, available: Int): Float
        open fun serialize(out: DataOutput2, value: Float): Unit
        open fun valueArraySearch(keys: Any, key: Float): Int
      open class SerializerFloatArray : GroupSerializerObjectArray<FloatArray>
        Module Contents SerializerFloatArray()
        open fun compare(o1: FloatArray, o2: FloatArray): Int
        open fun deserialize(in: DataInput2, available: Int): FloatArray
        open fun equals(a1: FloatArray, a2: FloatArray): Boolean
        open fun hashCode(floats: FloatArray, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: FloatArray): Unit
      abstract class SerializerFourByte<E : Any> : GroupSerializer<E>
        Module Contents SerializerFourByte()
        open fun fixedSize(): Int
        open fun isTrusted(): Boolean
        open fun valueArrayBinaryGet(input: DataInput2, keysLen: Int, pos: Int): E
        open fun valueArrayCopyOfRange(vals: Any, from: Int, to: Int): Any
        open fun valueArrayDeleteValue(vals: Any, pos: Int): Any
        open fun valueArrayDeserialize(in: DataInput2, size: Int): Any
        open fun valueArrayEmpty(): Any
        open fun valueArrayFromArray(objects: Array<Any>): Any
        open fun valueArrayGet(vals: Any, pos: Int): E
        open fun valueArrayPut(vals: Any, pos: Int, newValue: E): Any
        fun valueArraySearch(keys: Any, key: E, comparator: Comparator<Any>): Int
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
        open fun valueArraySize(vals: Any): Int
        open fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: E): Any
      open class SerializerIllegalAccess : GroupSerializerObjectArray<Any>
        Module Contents SerializerIllegalAccess()
        open fun deserialize(in: DataInput2, available: Int): Any
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: Any): Unit
      open class SerializerIntArray : GroupSerializerObjectArray<IntArray>
        Module Contents SerializerIntArray()
        open fun compare(o1: IntArray, o2: IntArray): Int
        open fun deserialize(in: DataInput2, available: Int): IntArray
        open fun equals(a1: IntArray, a2: IntArray): Boolean
        open fun hashCode(bytes: IntArray, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun nextValue(value: IntArray): IntArray
        open fun serialize(out: DataOutput2, value: IntArray): Unit
      open class SerializerInteger : SerializerFourByte<Int>
        Module Contents SerializerInteger()
        open fun deserialize(in: DataInput2, available: Int): Int
        open fun serialize(out: DataOutput2, value: Int): Unit
        open fun valueArrayBinarySearch(key: Int, input: DataInput2, keysLen: Int, comparator: Comparator<Any>): Int
        open fun valueArraySearch(keys: Any, key: Int): Int
      open class SerializerIntegerDelta : SerializerInteger
        Module Contents SerializerIntegerDelta()
        open fun deserialize(in: DataInput2, available: Int): Int
        open fun fixedSize(): Int
        open fun serialize(out: DataOutput2, value: Int): Unit
        open fun valueArrayBinaryGet(input: DataInput2, keysLen: Int, pos: Int): Int
        open fun valueArrayBinarySearch(key: Int, input: DataInput2, keysLen: Int, comparator: Comparator<Any>): Int
        open fun valueArrayDeserialize(in: DataInput2, size: Int): IntArray
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
      open class SerializerIntegerPacked : SerializerInteger
        Module Contents SerializerIntegerPacked()
        open fun deserialize(in: DataInput2, available: Int): Int
        open fun fixedSize(): Int
        open fun serialize(out: DataOutput2, value: Int): Unit
        open fun valueArrayBinaryGet(input: DataInput2, keysLen: Int, pos: Int): Int
        open fun valueArrayBinarySearch(key: Int, input: DataInput2, keysLen: Int, comparator: Comparator<Any>): Int
        open fun valueArrayDeserialize(in: DataInput2, size: Int): IntArray
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
      open class SerializerJava : GroupSerializerObjectArray<Any>
        Module Contents SerializerJava()
        open fun deserialize(in: DataInput2, available: Int): Any
        open fun serialize(out: DataOutput2, value: Any): Unit
        open fun valueArrayDeserialize(in: DataInput2, size: Int): Array<Any>
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
      open class SerializerLong : SerializerEightByte<Long>
        Module Contents SerializerLong()
        open fun deserialize(in: DataInput2, available: Int): Long
        open fun serialize(out: DataOutput2, value: Long): Unit
        open fun valueArrayBinarySearch(key: Long, input: DataInput2, keysLen: Int, comparator: Comparator<Any>): Int
        open fun valueArraySearch(keys: Any, key: Long): Int
      open class SerializerLongArray : GroupSerializerObjectArray<LongArray>
        Module Contents SerializerLongArray()
        open fun compare(o1: LongArray, o2: LongArray): Int
        open fun deserialize(in: DataInput2, available: Int): LongArray
        open fun equals(a1: LongArray, a2: LongArray): Boolean
        open fun hashCode(bytes: LongArray, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun nextValue(value: LongArray): LongArray
        open fun serialize(out: DataOutput2, value: LongArray): Unit
      open class SerializerLongDelta : SerializerLong
        Module Contents SerializerLongDelta()
        open fun deserialize(in: DataInput2, available: Int): Long
        open fun fixedSize(): Int
        open fun serialize(out: DataOutput2, value: Long): Unit
        open fun valueArrayBinaryGet(input: DataInput2, keysLen: Int, pos: Int): Long
        open fun valueArrayBinarySearch(key: Long, input: DataInput2, keysLen: Int, comparator: Comparator<Any>): Int
        open fun valueArrayDeserialize(in: DataInput2, size: Int): LongArray
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
      open class SerializerLongPacked : SerializerLong
        Module Contents SerializerLongPacked()
        open fun deserialize(in: DataInput2, available: Int): Long
        open fun fixedSize(): Int
        open fun serialize(out: DataOutput2, value: Long): Unit
        open fun valueArrayBinaryGet(input: DataInput2, keysLen: Int, pos: Int): Long
        open fun valueArrayBinarySearch(key: Long, input: DataInput2, keysLen: Int, comparator: Comparator<Any>): Int
        open fun valueArrayDeserialize(in: DataInput2, size: Int): LongArray
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
      open class SerializerRecid : SerializerEightByte<Long>
        Module Contents SerializerRecid()
        open fun deserialize(in: DataInput2, available: Int): Long
        open fun fixedSize(): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: Long): Unit
        open fun valueArrayBinaryGet(input: DataInput2, keysLen: Int, pos: Int): Long
        open fun valueArrayDeserialize(in: DataInput2, size: Int): LongArray
        open fun valueArraySearch(keys: Any, key: Long): Int
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
      open class SerializerRecidArray : SerializerLongArray
        Module Contents SerializerRecidArray()
        open fun deserialize(in: DataInput2, available: Int): LongArray
        open fun serialize(out: DataOutput2, value: LongArray): Unit
      open class SerializerShort : GroupSerializerObjectArray<Short>
        Module Contents SerializerShort()
        open fun deserialize(in: DataInput2, available: Int): Short
        open fun fixedSize(): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: Short): Unit
      open class SerializerShortArray : GroupSerializerObjectArray<ShortArray>
        Module Contents SerializerShortArray()
        open fun compare(o1: ShortArray, o2: ShortArray): Int
        open fun deserialize(in: DataInput2, available: Int): ShortArray
        open fun equals(a1: ShortArray, a2: ShortArray): Boolean
        open fun hashCode(shorts: ShortArray, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun nextValue(value: ShortArray): ShortArray
        open fun serialize(out: DataOutput2, value: ShortArray): Unit
      open class SerializerString : GroupSerializer<String>
        Module Contents SerializerString()
        open fun deserialize(in: DataInput2, available: Int): String
        open fun hashCode(s: String, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: String): Unit
        open fun valueArrayCopyOfRange(vals: Any, from: Int, to: Int): Array<CharArray>
        open fun valueArrayDeleteValue(vals: Any, pos: Int): Array<CharArray>
        open fun valueArrayDeserialize(in2: DataInput2, size: Int): Array<CharArray>
        open fun valueArrayEmpty(): Array<CharArray>
        open fun valueArrayFromArray(objects: Array<Any>): Array<CharArray>
        open fun valueArrayGet(vals: Any, pos: Int): String
        open fun valueArrayPut(vals: Any, pos: Int, newValue: String): Array<CharArray>
        open fun valueArraySearch(keys: Any, key: String): Int
        open fun valueArraySearch(vals: Any, key: String, comparator: Comparator<Any>): Int
        open fun valueArraySerialize(out2: DataOutput2, vals: Any): Unit
        open fun valueArraySize(vals: Any): Int
        open fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: String): Array<CharArray>
      open class SerializerStringAscii : GroupSerializerObjectArray<String>
        Module Contents SerializerStringAscii()
        open fun deserialize(in: DataInput2, available: Int): String
        open fun hashCode(s: String, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: String): Unit
      open class SerializerStringDelta : SerializerString
        Module Contents SerializerStringDelta()
        open fun valueArrayDeserialize(in: DataInput2, size: Int): Array<CharArray>
        open fun valueArraySerialize(out: DataOutput2, chars2: Any): Unit
      open class SerializerStringDelta2 : GroupSerializer<String>
        Module Contents SerializerStringDelta2()
        class ByteArrayKeys : StringArrayKeys
          Module Contents fun commonPrefixLen(): Int
          fun compare(pos1: Int, string: ByteArray): Int
          fun compare(pos1: Int, string: String): Int
          fun compare(pos1: Int, pos2: Int): Int
          fun copyOfRange(from: Int, to: Int): ByteArrayKeys
          fun deleteKey(pos: Int): ByteArrayKeys
          fun getKey(pos: Int): ByteArray
          fun getKeyString(pos: Int): String
          fun getOffset(): IntArray
          fun hasUnicodeChars(): Boolean
          fun length(): Int
          fun putKey(pos: Int, newKey: String): StringArrayKeys
          fun putKey(pos: Int, newKey: ByteArray): ByteArrayKeys
          fun serialize(out: DataOutput, prefixLen: Int): Unit
        class CharArrayKeys : StringArrayKeys
          Module Contents CharArrayKeys(in: DataInput2, offsets: IntArray, prefixLen: Int)
          fun commonPrefixLen(): Int
          fun compare(pos1: Int, string: String): Int
          fun compare(pos1: Int, pos2: Int): Int
          fun copyOfRange(from: Int, to: Int): CharArrayKeys
          fun deleteKey(pos: Int): CharArrayKeys
          fun getKeyString(pos: Int): String
          fun getOffset(): IntArray
          fun hasUnicodeChars(): Boolean
          fun length(): Int
          fun putKey(pos: Int, newKey: String): CharArrayKeys
          static fun putKey(kk: ByteArrayKeys, pos: Int, newKey: String): StringArrayKeys
          fun serialize(out: DataOutput, prefixLen: Int): Unit
        interface StringArrayKeys
          Module Contents abstract fun commonPrefixLen(): Int
          abstract fun compare(pos1: Int, string: String): Int
          abstract fun compare(pos1: Int, pos2: Int): Int
          abstract fun copyOfRange(from: Int, to: Int): StringArrayKeys
          abstract fun deleteKey(pos: Int): StringArrayKeys
          abstract fun getKeyString(pos: Int): String
          abstract fun getOffset(): IntArray
          abstract fun hasUnicodeChars(): Boolean
          abstract fun length(): Int
          abstract fun putKey(pos: Int, newKey: String): StringArrayKeys
          abstract fun serialize(out: DataOutput, prefixLen: Int): Unit
        open fun deserialize(input: DataInput2, available: Int): String
        open fun hashCode(s: String, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: String): Unit
        open fun valueArrayCopyOfRange(vals: Any, from: Int, to: Int): StringArrayKeys
        open fun valueArrayDeleteValue(vals: Any, pos: Int): StringArrayKeys
        open fun valueArrayDeserialize(in2: DataInput2, size: Int): StringArrayKeys
        open fun valueArrayEmpty(): StringArrayKeys
        open fun valueArrayFromArray(keys: Array<Any>): StringArrayKeys
        open fun valueArrayGet(vals: Any, pos: Int): String
        open fun valueArrayPut(vals: Any, pos: Int, newValue: String): Any
        open fun valueArraySearch(keys: Any, key: String): Int
        open fun valueArraySearch(keys: Any, key: String, comparator: Comparator<Any>): Int
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
        open fun valueArraySize(vals: Any): Int
        open fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: String): StringArrayKeys
      open class SerializerStringIntern : GroupSerializerObjectArray<String>
        Module Contents SerializerStringIntern()
        open fun deserialize(in: DataInput2, available: Int): String
        open fun hashCode(s: String, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: String): Unit
      open class SerializerStringNoSize : Serializer<String>
        Module Contents SerializerStringNoSize()
        open fun deserialize(in: DataInput2, available: Int): String
        open fun isTrusted(): Boolean
        open fun needsAvailableSizeHint(): Boolean
        open fun serialize(out: DataOutput2, value: String): Unit
      open class SerializerStringOrigHash : SerializerString
        Module Contents SerializerStringOrigHash()
        open fun deserialize(in: DataInput2, available: Int): String
        open fun hashCode(s: String, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: String): Unit
      open class SerializerUUID : GroupSerializer<UUID>
        Module Contents SerializerUUID()
        open fun deserialize(in: DataInput2, available: Int): UUID
        open fun equals(a1: UUID, a2: UUID): Boolean
        open fun fixedSize(): Int
        open fun hashCode(uuid: UUID, seed: Int): Int
        open fun isTrusted(): Boolean
        open fun serialize(out: DataOutput2, value: UUID): Unit
        open fun valueArrayCopyOfRange(vals: Any, from: Int, to: Int): Any
        open fun valueArrayDeleteValue(vals: Any, pos: Int): Any
        open fun valueArrayDeserialize(in: DataInput2, size: Int): Any
        open fun valueArrayEmpty(): Any
        open fun valueArrayFromArray(objects: Array<Any>): Any
        open fun valueArrayGet(vals: Any, pos: Int): UUID
        open fun valueArrayPut(vals: Any, pos: Int, newValue: UUID): Any
        open fun valueArraySearch(keys: Any, key: UUID): Int
        open fun valueArraySearch(keys: Any, key: UUID, comparator: Comparator<Any>): Int
        open fun valueArraySerialize(out: DataOutput2, vals: Any): Unit
        open fun valueArraySize(vals: Any): Int
        open fun valueArrayUpdateVal(vals: Any, pos: Int, newValue: UUID): Any
      class SerializerUtils
        Module Contents SerializerUtils()
        static fun compareInt(x: Int, y: Int): Int
        static fun <R : Any> serializerForClass(clazz: Class<R>): Serializer<R>
    package org.mapdb.volume
      Module Contents class ByteArrayVol : Volume
        Module Contents ByteArrayVol()
        ByteArrayVol(sliceShift: Int, initSize: Long)
        static val FACTORY: VolumeFactory
        fun clear(startOffset: Long, endOffset: Long): Unit
        fun close(): Unit
        fun copyTo(inputOffset: Long, target: Volume, targetOffset: Long, size: Long): Unit
        fun ensureAvailable(offset: Long): Unit
        fun getByte(offset: Long): Byte
        fun getData(offset: Long, bytes: ByteArray, bytesPos: Int, length: Int): Unit
        fun getDataInput(offset: Long, size: Int): DataInput2
        fun getDataInputOverlap(offset: Long, size: Int): DataInput2
        fun getFile(): File
        fun getFileLocked(): Boolean
        fun getInt(offset: Long): Int
        fun getLong(offset: Long): Long
        fun isReadOnly(): Boolean
        fun isSliced(): Boolean
        fun length(): Long
        fun putByte(offset: Long, value: Byte): Unit
        fun putData(offset: Long, src: ByteArray, srcPos: Int, srcSize: Int): Unit
        fun putData(offset: Long, buf: ByteBuffer): Unit
        fun putDataOverlap(offset: Long, data: ByteArray, pos: Int, len: Int): Unit
        fun putInt(offset: Long, value: Int): Unit
        fun putLong(offset: Long, v: Long): Unit
        fun sliceSize(): Int
        fun sync(): Unit
        fun truncate(size: Long): Unit
      class ByteBufferMemoryVol : ByteBufferVol
        Module Contents ByteBufferMemoryVol(useDirectBuffer: Boolean, sliceShift: Int, cleanerHackEnabled: Boolean, initSize: Long)
        static val FACTORY: VolumeFactory
        static val FACTORY_WITH_CLEANER_HACK: VolumeFactory
        fun close(): Unit
        fun ensureAvailable(offset: Long): Unit
        fun getFile(): File
        fun getFileLocked(): Boolean
        fun isReadOnly(): Boolean
        fun length(): Long
        fun sync(): Unit
        fun toString(): String
        fun truncate(size: Long): Unit
      class ByteBufferMemoryVolSingle : ByteBufferVolSingle
        Module Contents ByteBufferMemoryVolSingle(useDirectBuffer: Boolean, maxSize: Long, cleanerHackEnabled: Boolean)
        fun close(): Unit
        fun getFile(): File
        fun getFileLocked(): Boolean
        fun isReadOnly(): Boolean
        fun length(): Long
        fun sync(): Unit
        fun toString(): String
        fun truncate(size: Long): Unit
      abstract class ByteBufferVol : Volume
        Module Contents open fun clear(startOffset: Long, endOffset: Long): Unit
        open fun copyTo(inputOffset: Long, target: Volume, targetOffset: Long, size: Long): Unit
        fun getByte(offset: Long): Byte
        open fun getData(offset: Long, src: ByteArray, srcPos: Int, srcSize: Int): Unit
        fun getDataInput(offset: Long, size: Int): ByteBuffer
        open fun getDataInputOverlap(offset: Long, size: Int): DataInput2
        fun getInt(offset: Long): Int
        fun getLong(offset: Long): Long
        open fun getPackedLong(position: Long): Long
        open fun getSixLong(pos: Long): Long
        open fun getUnsignedByte(offset: Long): Int
        open fun getUnsignedShort(offset: Long): Int
        open fun isSliced(): Boolean
        fun putByte(offset: Long, value: Byte): Unit
        open fun putData(offset: Long, src: ByteArray, srcPos: Int, srcSize: Int): Unit
        fun putData(offset: Long, buf: ByteBuffer): Unit
        open fun putDataOverlap(offset: Long, data: ByteArray, pos: Int, len: Int): Unit
        fun putInt(offset: Long, value: Int): Unit
        fun putLong(offset: Long, value: Long): Unit
        open fun putPackedLong(pos: Long, value: Long): Int
        open fun putSixLong(pos: Long, value: Long): Unit
        open fun putUnsignedByte(offset: Long, byt: Int): Unit
        open fun putUnsignedShort(offset: Long, value: Int): Unit
        open fun sliceSize(): Int
      abstract class ByteBufferVolSingle : Volume
        Module Contents open fun clear(startOffset: Long, endOffset: Long): Unit
        open fun copyTo(inputOffset: Long, target: Volume, targetOffset: Long, size: Long): Unit
        open fun ensureAvailable(offset: Long): Unit
        fun getByte(offset: Long): Byte
        open fun getData(offset: Long, src: ByteArray, srcPos: Int, srcSize: Int): Unit
        fun getDataInput(offset: Long, size: Int): ByteBuffer
        open fun getDataInputOverlap(offset: Long, size: Int): DataInput2
        fun getInt(offset: Long): Int
        fun getLong(offset: Long): Long
        open fun isSliced(): Boolean
        fun putByte(offset: Long, value: Byte): Unit
        open fun putData(offset: Long, src: ByteArray, srcPos: Int, srcSize: Int): Unit
        fun putData(offset: Long, buf: ByteBuffer): Unit
        open fun putDataOverlap(offset: Long, data: ByteArray, pos: Int, len: Int): Unit
        fun putInt(offset: Long, value: Int): Unit
        fun putLong(offset: Long, value: Long): Unit
        open fun sliceSize(): Int
      class FileChannelVol : Volume
        Module Contents FileChannelVol(file: File, readOnly: Boolean, fileLockWait: Long, sliceShift: Int, initSize: Long)
        FileChannelVol(file: File)
        static val FACTORY: VolumeFactory
        fun clear(startOffset: Long, endOffset: Long): Unit
        static fun clear(channel: FileChannel, startOffset: Long, endOffset: Long): Unit
        fun close(): Unit
        fun ensureAvailable(offset: Long): Unit
        fun getByte(offset: Long): Byte
        fun getData(offset: Long, bytes: ByteArray, bytesPos: Int, size: Int): Unit
        fun getDataInput(offset: Long, size: Int): ByteBuffer
        fun getFile(): File
        fun getFileLocked(): Boolean
        fun getInt(offset: Long): Int
        fun getLong(offset: Long): Long
        fun isReadOnly(): Boolean
        fun isSliced(): Boolean
        fun length(): Long
        fun putByte(offset: Long, value: Byte): Unit
        fun putData(offset: Long, src: ByteArray, srcPos: Int, srcSize: Int): Unit
        fun putData(offset: Long, buf: ByteBuffer): Unit
        fun putInt(offset: Long, value: Int): Unit
        fun putLong(offset: Long, value: Long): Unit
        fun sliceSize(): Int
        fun sync(): Unit
        fun truncate(size: Long): Unit
      class MappedFileVol : ByteBufferVol
        Module Contents MappedFileVol(file: File, readOnly: Boolean, fileLockWait: Long, sliceShift: Int, cleanerHackEnabled: Boolean, initSize: Long, preclearDisabled: Boolean)
        static val FACTORY: VolumeFactory
        class MappedFileFactory : VolumeFactory
          Module Contents MappedFileFactory(cleanerHackEnabled: Boolean, preclearDisabled: Boolean)
          open fun exists(file: String): Boolean
          open fun handlesReadonly(): Boolean
          open fun makeVolume(file: String, readOnly: Boolean, fileLockWait: Long, sliceShift: Int, initSize: Long, fixedSize: Boolean): Volume
        fun close(): Unit
        fun ensureAvailable(offset: Long): Unit
        fun fileLoad(): Boolean
        fun getFile(): File
        fun getFileLocked(): Boolean
        fun isReadOnly(): Boolean
        fun length(): Long
        fun sync(): Unit
        fun truncate(size: Long): Unit
      class MappedFileVolSingle : ByteBufferVolSingle
        Module Contents MappedFileVolSingle(file: File, readOnly: Boolean, fileLockWait: Long, maxSize: Long, cleanerHackEnabled: Boolean)
        fun close(): Unit
        fun fileLoad(): Boolean
        fun getFile(): File
        fun getFileLocked(): Boolean
        fun isReadOnly(): Boolean
        fun length(): Long
        fun sync(): Unit
        fun truncate(size: Long): Unit
      class RandomAccessFileVol : Volume
        Module Contents RandomAccessFileVol(file: File, readOnly: Boolean, fileLockWait: Long, initSize: Long)
        static val FACTORY: VolumeFactory
        fun clear(startOffset: Long, endOffset: Long): Unit
        fun close(): Unit
        fun ensureAvailable(offset: Long): Unit
        fun getByte(offset: Long): Byte
        fun getData(offset: Long, bytes: ByteArray, bytesPos: Int, size: Int): Unit
        fun getDataInput(offset: Long, size: Int): DataInput2
        fun getFile(): File
        fun getFileLocked(): Boolean
        fun getInt(offset: Long): Int
        fun getLong(offset: Long): Long
        fun getPackedLong(pos: Long): Long
        fun getSixLong(offset: Long): Long
        fun getUnsignedShort(offset: Long): Int
        fun isReadOnly(): Boolean
        fun isSliced(): Boolean
        fun length(): Long
        fun putByte(offset: Long, value: Byte): Unit
        fun putData(offset: Long, src: ByteArray, srcPos: Int, srcSize: Int): Unit
        fun putData(offset: Long, buf: ByteBuffer): Unit
        fun putInt(offset: Long, value: Int): Unit
        fun putLong(offset: Long, value: Long): Unit
        fun putPackedLong(pos: Long, value: Long): Int
        fun putSixLong(pos: Long, value: Long): Unit
        fun putUnsignedShort(offset: Long, value: Int): Unit
        fun sliceSize(): Int
        fun sync(): Unit
        fun truncate(size: Long): Unit
      class ReadOnlyVolume : Volume
        Module Contents ReadOnlyVolume(vol: Volume)
        fun clear(startOffset: Long, endOffset: Long): Unit
        fun close(): Unit
        fun copyTo(inputOffset: Long, target: Volume, targetOffset: Long, size: Long): Unit
        fun deleteFile(): Unit
        fun ensureAvailable(offset: Long): Unit
        fun getByte(offset: Long): Byte
        fun getData(offset: Long, bytes: ByteArray, bytesPos: Int, size: Int): Unit
        fun getDataInput(offset: Long, size: Int): DataInput2
        fun getDataInputOverlap(offset: Long, size: Int): DataInput2
        fun getFile(): File
        fun getFileLocked(): Boolean
        fun getInt(offset: Long): Int
        fun getLong(offset: Long): Long
        fun getSixLong(pos: Long): Long
        fun getUnsignedByte(offset: Long): Int
        fun getUnsignedShort(offset: Long): Int
        fun isClosed(): Boolean
        fun isReadOnly(): Boolean
        fun isSliced(): Boolean
        fun length(): Long
        fun putByte(offset: Long, value: Byte): Unit
        fun putData(offset: Long, src: ByteArray, srcPos: Int, srcSize: Int): Unit
        fun putData(offset: Long, buf: ByteBuffer): Unit
        fun putDataOverlap(offset: Long, src: ByteArray, srcPos: Int, srcSize: Int): Unit
        fun putInt(offset: Long, value: Int): Unit
        fun putLong(offset: Long, value: Long): Unit
        fun putSixLong(pos: Long, value: Long): Unit
        fun putUnsignedByte(offset: Long, b: Int): Unit
        fun putUnsignedShort(offset: Long, value: Int): Unit
        fun sliceSize(): Int
        fun sync(): Unit
        fun truncate(size: Long): Unit
      class ReadOnlyVolumeFactory : VolumeFactory
        Module Contents ReadOnlyVolumeFactory(volfab: VolumeFactory)
        fun exists(file: String?): Boolean
        fun handlesReadonly(): Boolean
        fun makeVolume(file: String?, readOnly: Boolean, fileLockWait: Long, sliceShift: Int, initSize: Long, fixedSize: Boolean): Volume?
        protected val volfab: VolumeFactory
      class SingleByteArrayVol : Volume
        Module Contents SingleByteArrayVol(size: Int)
        SingleByteArrayVol(data: ByteArray)
        fun clear(startOffset: Long, endOffset: Long): Unit
        fun close(): Unit
        fun copyTo(inputOffset: Long, target: Volume, targetOffset: Long, size: Long): Unit
        fun ensureAvailable(offset: Long): Unit
        fun getByte(offset: Long): Byte
        fun getData(offset: Long, bytes: ByteArray, bytesPos: Int, length: Int): Unit
        fun getDataInput(offset: Long, size: Int): DataInput2
        fun getFile(): File
        fun getFileLocked(): Boolean
        fun getInt(offset: Long): Int
        fun getLong(offset: Long): Long
        fun isReadOnly(): Boolean
        fun isSliced(): Boolean
        fun length(): Long
        fun putByte(offset: Long, value: Byte): Unit
        fun putData(offset: Long, src: ByteArray, srcPos: Int, srcSize: Int): Unit
        fun putData(offset: Long, buf: ByteBuffer): Unit
        fun putInt(offset: Long, value: Int): Unit
        fun putLong(offset: Long, v: Long): Unit
        fun sliceSize(): Int
        fun sync(): Unit
        fun truncate(size: Long): Unit
      abstract class Volume : Closeable
        Module Contents Volume()
        static val UNSAFE_VOL_FACTORY: VolumeFactory
        open fun assertZeroes(startOffset: Long, endOffset: Long): Unit
        abstract fun clear(startOffset: Long, endOffset: Long): Unit
        open fun clearOverlap(startOffset: Long, endOffset: Long): Unit
        abstract fun close(): Unit
        open fun copyFrom(input: InputStream): Unit
        open fun copyTo(inputOffset: Long, target: Volume, targetOffset: Long, size: Long): Unit
        open fun copyTo(to: Volume): Unit
        open fun copyTo(output: OutputStream): Unit
        open fun deleteFile(): Unit
        abstract fun ensureAvailable(offset: Long): Unit
        open fun fileLoad(): Boolean
        abstract fun getByte(offset: Long): Byte
        abstract fun getData(offset: Long, bytes: ByteArray, bytesPos: Int, size: Int): Unit
        abstract fun getDataInput(offset: Long, size: Int): DataInput2
        open fun getDataInputOverlap(offset: Long, size: Int): DataInput2
        abstract fun getFile(): File
        abstract fun getFileLocked(): Boolean
        abstract fun getInt(offset: Long): Int
        abstract fun getLong(offset: Long): Long
        open fun getPackedLong(position: Long): Long
        open fun getSixLong(pos: Long): Long
        open fun getUnsignedByte(offset: Long): Int
        open fun getUnsignedShort(offset: Long): Int
        open fun hash(off: Long, len: Long, seed: Long): Long
        open fun isClosed(): Boolean
        abstract fun isReadOnly(): Boolean
        abstract fun isSliced(): Boolean
        abstract fun length(): Long
        abstract fun putByte(offset: Long, value: Byte): Unit
        abstract fun putData(offset: Long, src: ByteArray, srcPos: Int, srcSize: Int): Unit
        abstract fun putData(offset: Long, buf: ByteBuffer): Unit
        open fun putDataOverlap(offset: Long, src: ByteArray, srcPos: Int, srcSize: Int): Unit
        abstract fun putInt(offset: Long, value: Int): Unit
        abstract fun putLong(offset: Long, value: Long): Unit
        open fun putPackedLong(pos: Long, value: Long): Int
        open fun putSixLong(pos: Long, value: Long): Unit
        open fun putUnsignedByte(offset: Long, b: Int): Unit
        open fun putUnsignedShort(offset: Long, value: Int): Unit
        abstract fun sliceSize(): Int
        abstract fun sync(): Unit
        abstract fun truncate(size: Long): Unit
      abstract class VolumeFactory
        Module Contents VolumeFactory()
        abstract fun exists(file: String): Boolean
        abstract fun handlesReadonly(): Boolean
        abstract fun makeVolume(file: String, readOnly: Boolean, fileLockWait: Long, sliceShift: Int, initSize: Long, fixedSize: Boolean): Volume
        open fun makeVolume(file: String, readOnly: Boolean): Volume
        open fun makeVolume(file: String, readOnly: Boolean, fileLockWait: Long): Volume
        open static fun wrap(volume: Volume, exists: Boolean): VolumeFactory