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>
abstract class BTreeIterator<K, V>
abstract class DescendingBoundIterator<K, V>
abstract class DescendingIterator<K, V>
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
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(: K?, : Boolean, : K?, : Boolean): MutableIterator<MutableEntry<K, V?>>
abstract fun descendingKeyIterator(): MutableIterator<K>
abstract fun descendingKeyIterator(: K?, : Boolean, : K?, : Boolean): MutableIterator<K>
abstract fun descendingValueIterator(): MutableIterator<V?>
abstract fun descendingValueIterator(: K?, : Boolean, : K?, : Boolean): MutableIterator<V?>
abstract fun entryIterator(: K?, : Boolean, : K?, : Boolean): MutableIterator<MutableEntry<K, V?>>
abstract fun findHigher(: K?, : Boolean): MutableEntry<K, V>?
abstract fun findHigherKey(: K?, : Boolean): K?
abstract fun findLower(: K?, : Boolean): MutableEntry<K, V>?
abstract fun findLowerKey(: K?, : Boolean): K?
abstract val hasValues: Boolean
abstract fun keyIterator(): MutableIterator<K>
abstract fun keyIterator(: K?, : Boolean, : K?, : Boolean): MutableIterator<K?>
abstract fun valueIterator(: K?, : Boolean, : K?, : 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>
class AtomicIntegerMaker : Maker<Integer>
class AtomicLongMaker : Maker<Long>
class AtomicStringMaker : Maker<String>
class AtomicVarMaker<E> : Maker<Var<E>>
protected data class CatVal
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>>
class IndexTreeListMaker<E> : Maker<IndexTreeList<E>>
class IndexTreeLongLongMapMaker : Maker<IndexTreeLongLongMap>
object Keys
abstract class Maker<E>
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>>
class TreeSetMaker<E> : Maker<NavigableSet<E>>
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
object DBMaker
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>
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?>
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>
object Pump
class QueueLong : Verifiable
Module Contents
QueueLong(store: Store, tailRecid: Long, headRecid: Long, headPrevRecid: Long)
data class Node
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
class SerializerElsa : GroupSerializerObjectArray<Any?>
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>
protected class NodeIterator
abstract class Sink<K, V> : Sink<<ERROR CLASS><K, V>, SortedTableMap<K, V>>
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
interface StoreBinary : Store
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, : Boolean, : 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, : Boolean = true, : 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, : Boolean, : 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
class StoreOnHeap : Store
class StoreReadOnlyWrapper : Store
open class StoreTrivial : Store
class StoreTrivialTx : StoreTrivial, StoreTx
interface StoreTx : Store
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, : Boolean, : 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, : Boolean = true, : 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
package org.mapdb
Module Contents
class Atomic
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>
abstract class BTreeIterator<K, V>
abstract class DescendingBoundIterator<K, V>
abstract class DescendingIterator<K, V>
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
interface CC
interface ConcurrencyAware
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(: K?, : Boolean, : K?, : Boolean): MutableIterator<MutableEntry<K, V?>>
abstract fun descendingKeyIterator(): MutableIterator<K>
abstract fun descendingKeyIterator(: K?, : Boolean, : K?, : Boolean): MutableIterator<K>
abstract fun descendingValueIterator(): MutableIterator<V?>
abstract fun descendingValueIterator(: K?, : Boolean, : K?, : Boolean): MutableIterator<V?>
abstract fun entryIterator(: K?, : Boolean, : K?, : Boolean): MutableIterator<MutableEntry<K, V?>>
abstract fun findHigher(: K?, : Boolean): MutableEntry<K, V>?
abstract fun findHigherKey(: K?, : Boolean): K?
abstract fun findLower(: K?, : Boolean): MutableEntry<K, V>?
abstract fun findLowerKey(: K?, : Boolean): K?
abstract val hasValues: Boolean
abstract fun keyIterator(): MutableIterator<K>
abstract fun keyIterator(: K?, : Boolean, : K?, : Boolean): MutableIterator<K?>
abstract fun valueIterator(: K?, : Boolean, : K?, : 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>
class AtomicIntegerMaker : Maker<Integer>
class AtomicLongMaker : Maker<Long>
class AtomicStringMaker : Maker<String>
class AtomicVarMaker<E> : Maker<Var<E>>
protected data class CatVal
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>>
class IndexTreeListMaker<E> : Maker<IndexTreeList<E>>
class IndexTreeLongLongMapMaker : Maker<IndexTreeLongLongMap>
object Keys
abstract class Maker<E>
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>>
class TreeSetMaker<E> : Maker<NavigableSet<E>>