Search in sources :

Example 1 with ContractKey

use of com.hedera.services.state.virtual.ContractKey in project hedera-services by hashgraph.

the class ContractBench method prepare.

@Setup
public void prepare() throws Exception {
    pipeline = new Pipeline<>();
    final long estimatedNumKeyValuePairs = (long) (numContracts * (1 - bigPercent - hugePercent) * ((kbPerContract * 1024L) / ESTIMATED_KEY_VALUE_SIZE)) + (long) (numContracts * bigPercent * ((kbPerBigContract * 1024L) / ESTIMATED_KEY_VALUE_SIZE)) + (long) (numContracts * hugePercent * ((kbPerHugeContract * 1024L) / ESTIMATED_KEY_VALUE_SIZE));
    System.out.println("estimatedNumKeyValuePairs = " + estimatedNumKeyValuePairs);
    VirtualLeafRecordSerializer<ContractKey, ContractValue> virtualLeafRecordSerializer = new VirtualLeafRecordSerializer<>((short) 1, DigestType.SHA_384, (short) 1, DataFileCommon.VARIABLE_DATA_SIZE, new ContractKeySupplier(), (short) 1, ContractValue.SERIALIZED_SIZE, new ContractValueSupplier(), true);
    Path dataSourcePath = getDataSourcePath(dsType);
    boolean dataSourceDirExisted = Files.exists(dataSourcePath);
    virtualMap = createMap(dsType, virtualLeafRecordSerializer, new ContractKeySerializer(), estimatedNumKeyValuePairs, dataSourcePath, preferDiskBasedIndexes);
    txProcessor = new TransactionProcessor<>(preFetchEventHandlers, (Transaction<Data> tx) -> {
        // preFetch logic
        VirtualMap<ContractKey, ContractValue> map = getVirtualMap();
        final Data data = tx.getData();
        data.value1 = map.getForModify(data.key1);
        data.value2 = map.getForModify(data.key2);
    }, (Transaction<Data> tx) -> {
        // handleTransaction logic
        final Data data = tx.getData();
        data.value1.setValue(data.value1.asLong() - data.transferAmount);
        data.value2.setValue(data.value2.asLong() + data.transferAmount);
    });
    // We generate a different number of key/value pairs depending on whether it is
    // a huge contract, big contract, or normal contract
    int numBigContracts = (int) (numContracts * bigPercent);
    System.out.println("numBigContracts = " + numBigContracts);
    int numHugeContracts = (int) (numContracts * hugePercent);
    System.out.println("numHugeContracts = " + numHugeContracts);
    keyValuePairsPerContract = new int[numContracts];
    for (int i = 0; i < numContracts; i++) {
        final int kb;
        if (i > 0 && (i % 100) == 0 && numHugeContracts > 0) {
            kb = kbPerHugeContract;
            numHugeContracts--;
        } else if (i > 0 && (i % 10) == 0 && numBigContracts > 0) {
            kb = kbPerBigContract;
            numBigContracts--;
        } else {
            kb = kbPerContract;
        }
        final var numKeyValuePairs = (kb * 1024L) / ESTIMATED_KEY_VALUE_SIZE;
        keyValuePairsPerContract[i] = (int) numKeyValuePairs;
    }
    if (!dataSourceDirExisted && preFill) {
        long countOfKeyValuePairs = 0;
        long lastCountOfKeyValuePairs = 0;
        for (int i = 0; i < numContracts; i++) {
            if ((countOfKeyValuePairs - lastCountOfKeyValuePairs) > 100_000) {
                lastCountOfKeyValuePairs = countOfKeyValuePairs;
                System.out.printf("Completed: %,d contracts and %,d key/value pairs\n", i, countOfKeyValuePairs);
                virtualMap = pipeline.endRound(virtualMap);
            }
            if (i > 0 && i % 10000 == 0) {
                System.out.println("=============== GC =======================");
                // loading is really intense so give GC a chance to catch up
                System.gc();
                Thread.sleep(1000);
            }
            final int numKeyValuePairs = keyValuePairsPerContract[i];
            for (int j = 0; j < numKeyValuePairs; j++) {
                final var key = asContractKey(i, j);
                final var value = new ContractValue(j);
                try {
                    virtualMap.put(key, value);
                } catch (Exception e) {
                    e.printStackTrace();
                    System.err.println(i + ":" + j);
                    throw e;
                }
            }
            countOfKeyValuePairs += numKeyValuePairs;
        }
        // During setup, we perform the full hashing and release the old copy. This way,
        // during the tests, we don't have an initial slow hash.
        System.out.printf("Completed: %,d contracts and %,d key/value pairs\n", numContracts, countOfKeyValuePairs);
        virtualMap = pipeline.endRound(virtualMap);
    } else {
        System.out.println("NOT PRE_FILLING AS LOADED FROM FILES OR TURNED OFF WITH FLAG!");
    }
    printDataStoreSize();
    // create a snapshot every 15min
    DateFormat df = new SimpleDateFormat("yyyy-MM-dd--HH-mm");
    ScheduledExecutorService snapshotting = Executors.newScheduledThreadPool(1, runnable -> new Thread(runnable, "Snapshot"));
    snapshotting.scheduleWithFixedDelay(() -> {
        final Path snapshotDir = Path.of("jasperdb_snapshot_" + df.format(new Date()));
        System.out.println("************ STARTING SNAPSHOT [" + snapshotDir.toAbsolutePath() + "] ***********");
        long START = System.currentTimeMillis();
        try {
            virtualMap.getDataSource().snapshot(snapshotDir);
        } catch (IOException e) {
            e.printStackTrace();
        }
        double tookSeconds = (System.currentTimeMillis() - START) * Units.MILLISECONDS_TO_SECONDS;
        System.out.printf("************ SNAPSHOT FINISHED took %,3f seconds [%s] ***********\n", tookSeconds, snapshotDir.toAbsolutePath());
    }, 0, 5, TimeUnit.MINUTES);
}
Also used : ContractValue(com.hedera.services.state.virtual.ContractValue) ContractKey(com.hedera.services.state.virtual.ContractKey) ContractValueSupplier(com.hedera.services.state.virtual.ContractValueSupplier) ContractKeySupplier(com.hedera.services.state.virtual.ContractKeySupplier) Path(java.nio.file.Path) VFCMapBenchBase.getDataSourcePath(virtual.VFCMapBenchBase.getDataSourcePath) ScheduledExecutorService(java.util.concurrent.ScheduledExecutorService) VirtualLeafRecordSerializer(com.swirlds.jasperdb.VirtualLeafRecordSerializer) IOException(java.io.IOException) IOException(java.io.IOException) Date(java.util.Date) VirtualMap(com.swirlds.virtualmap.VirtualMap) SimpleDateFormat(java.text.SimpleDateFormat) DateFormat(java.text.DateFormat) ContractKeySerializer(com.hedera.services.state.virtual.ContractKeySerializer) SimpleDateFormat(java.text.SimpleDateFormat) Setup(org.openjdk.jmh.annotations.Setup)

Example 2 with ContractKey

use of com.hedera.services.state.virtual.ContractKey in project hedera-services by hashgraph.

the class UpdateBench method updateLeavesAndInternals.

@Benchmark
public void updateLeavesAndInternals(DatabaseMergingState databaseState) throws IOException {
    var internalRecordStream = IntStream.range(0, NUMBER_OF_INTERNALS_CHANGED_PER_FLUSH).mapToObj(i -> new VirtualInternalRecord(randomInternalPaths[i], hash((int) randomInternalPaths[i])));
    var leafRecordStream = IntStream.range(0, NUMBER_OF_LEAVES_CHANGED_PER_FLUSH).mapToObj(i -> {
        final long path = randomLeafPaths[i];
        return new VirtualLeafRecord<>(path, hash((int) path), new ContractKey(path, path), new ContractValue(path));
    });
    databaseState.dataSource.saveRecords(databaseState.dataSource.getFirstLeafPath(), databaseState.dataSource.getLastLeafPath(), internalRecordStream, leafRecordStream, Stream.empty());
}
Also used : ContractValue(com.hedera.services.state.virtual.ContractValue) ContractKey(com.hedera.services.state.virtual.ContractKey) VirtualLeafRecord(com.swirlds.virtualmap.datasource.VirtualLeafRecord) VirtualInternalRecord(com.swirlds.virtualmap.datasource.VirtualInternalRecord) Benchmark(org.openjdk.jmh.annotations.Benchmark)

Example 3 with ContractKey

use of com.hedera.services.state.virtual.ContractKey in project hedera-services by hashgraph.

the class ThorsFileHammer method updateAllValues.

public void updateAllValues() {
    try {
        final int batchSize = 1000;
        final int numOfBatches = (int) ((fileCollection.getMaximumValidKey() - fileCollection.getMinimumValidKey()) / batchSize);
        System.out.println("ThorsHammer.updateAllValues numOfBatches=" + numOfBatches);
        for (int batchIndex = 0; batchIndex < numOfBatches; batchIndex++) {
            final int firstLeaf = (int) (fileCollection.getMinimumValidKey() + (batchIndex * batchSize));
            final int lastLeaf = firstLeaf + batchSize;
            final var leafRecordStream = LongStream.range(firstLeaf, lastLeaf).mapToObj(path -> new VirtualLeafRecord<>(path, hash((int) path), new ContractKey(path / 1000, path), new ContractValue(RANDOM.nextLong()))).peek(leaf -> compareToMe.set((int) leaf.getPath(), (int) leaf.getValue().asLong()));
            try {
                readWriteLock.writeLock().lock();
                fileCollection.startWriting();
                final Map<Long, Long> indexUpdates = new HashMap<>();
                leafRecordStream.forEach(leaf -> {
                    try {
                        indexUpdates.put(leaf.getPath(), fileCollection.storeDataItem(leaf));
                    } catch (IOException e) {
                        e.printStackTrace();
                    }
                });
                final var dataFile = fileCollection.endWriting(fileCollection.getMinimumValidKey(), fileCollection.getMaximumValidKey());
                for (var update : indexUpdates.entrySet()) {
                    index.put(update.getKey(), update.getValue());
                }
                dataFile.setFileAvailableForMerging(true);
            } finally {
                readWriteLock.writeLock().unlock();
            }
        }
    } catch (IOException e) {
        e.printStackTrace();
    }
}
Also used : ContractValueSupplier(com.hedera.services.state.virtual.ContractValueSupplier) CommonTestUtils.hash(utils.CommonTestUtils.hash) LongStream(java.util.stream.LongStream) Files(java.nio.file.Files) ContractKey(com.hedera.services.state.virtual.ContractKey) ContractValue(com.hedera.services.state.virtual.ContractValue) CommonTestUtils.deleteDirectoryAndContents(utils.CommonTestUtils.deleteDirectoryAndContents) VirtualLeafRecordSerializer(com.swirlds.jasperdb.VirtualLeafRecordSerializer) AtomicBoolean(java.util.concurrent.atomic.AtomicBoolean) DataFileCommon(com.swirlds.jasperdb.files.DataFileCommon) IOException(java.io.IOException) HashMap(java.util.HashMap) Random(java.util.Random) ReentrantReadWriteLock(java.util.concurrent.locks.ReentrantReadWriteLock) DataFileCollection(com.swirlds.jasperdb.files.DataFileCollection) ContractKeySupplier(com.hedera.services.state.virtual.ContractKeySupplier) DigestType(com.swirlds.common.crypto.DigestType) Map(java.util.Map) VirtualLeafRecord(com.swirlds.virtualmap.datasource.VirtualLeafRecord) LongListOffHeap(com.swirlds.jasperdb.collections.LongListOffHeap) Path(java.nio.file.Path) AtomicIntegerArray(java.util.concurrent.atomic.AtomicIntegerArray) ContractValue(com.hedera.services.state.virtual.ContractValue) ContractKey(com.hedera.services.state.virtual.ContractKey) HashMap(java.util.HashMap) VirtualLeafRecord(com.swirlds.virtualmap.datasource.VirtualLeafRecord) IOException(java.io.IOException)

Example 4 with ContractKey

use of com.hedera.services.state.virtual.ContractKey in project hedera-services by hashgraph.

the class ThorsHammer method updateAllValues.

public void updateAllValues() {
    try {
        final int batchSize = 1000;
        final int numOfBatches = (int) ((dataSource.getLastLeafPath() - dataSource.getFirstLeafPath()) / batchSize);
        System.out.println("ThorsHammer.updateAllValues numOfBatches=" + numOfBatches);
        for (int batchIndex = 0; batchIndex < numOfBatches; batchIndex++) {
            final int firstLeaf = (int) (dataSource.getFirstLeafPath() + (batchIndex * batchSize));
            final int lastLeaf = firstLeaf + batchSize;
            readExclusionZoneFirstLeafPath.set(firstLeaf);
            readExclusionZoneLastLeafPath.set(lastLeaf);
            final var leafRecordStream = LongStream.range(firstLeaf, lastLeaf).mapToObj(path -> new VirtualLeafRecord<>(path, hash((int) path), new ContractKey(path / 1000, path), new ContractValue(RANDOM.nextLong()))).peek(leaf -> compareToMe.set((int) leaf.getPath(), (int) leaf.getValue().asLong()));
            // try {
            // readWriteLock.writeLock().lock();
            dataSource.saveRecords(dataSource.getFirstLeafPath(), dataSource.getLastLeafPath(), Stream.empty(), leafRecordStream, Stream.empty());
            // } finally {
            // readWriteLock.writeLock().unlock();
            // }
            Thread.sleep(5);
        }
    } catch (IOException | InterruptedException e) {
        e.printStackTrace();
    }
}
Also used : ContractValueSupplier(com.hedera.services.state.virtual.ContractValueSupplier) JasperDbBuilder(com.swirlds.jasperdb.JasperDbBuilder) ContractKey(com.hedera.services.state.virtual.ContractKey) VirtualInternalRecordSerializer(com.swirlds.jasperdb.VirtualInternalRecordSerializer) CommonTestUtils.deleteDirectoryAndContents(utils.CommonTestUtils.deleteDirectoryAndContents) VirtualLeafRecordSerializer(com.swirlds.jasperdb.VirtualLeafRecordSerializer) DataFileCommon(com.swirlds.jasperdb.files.DataFileCommon) HashMap(java.util.HashMap) Random(java.util.Random) ReentrantReadWriteLock(java.util.concurrent.locks.ReentrantReadWriteLock) ContractKeySupplier(com.hedera.services.state.virtual.ContractKeySupplier) Map(java.util.Map) VirtualLeafRecord(com.swirlds.virtualmap.datasource.VirtualLeafRecord) Path(java.nio.file.Path) AtomicIntegerArray(java.util.concurrent.atomic.AtomicIntegerArray) CommonTestUtils.hash(utils.CommonTestUtils.hash) LongStream(java.util.stream.LongStream) VirtualDataSourceJasperDB(com.swirlds.jasperdb.VirtualDataSourceJasperDB) Files(java.nio.file.Files) CommonUtils.hardLinkTree(com.swirlds.common.CommonUtils.hardLinkTree) ContractValue(com.hedera.services.state.virtual.ContractValue) IOException(java.io.IOException) DigestType(com.swirlds.common.crypto.DigestType) VirtualInternalRecord(com.swirlds.virtualmap.datasource.VirtualInternalRecord) AtomicLong(java.util.concurrent.atomic.AtomicLong) Stream(java.util.stream.Stream) ContractKeySerializer(com.hedera.services.state.virtual.ContractKeySerializer) ContractValue(com.hedera.services.state.virtual.ContractValue) ContractKey(com.hedera.services.state.virtual.ContractKey) VirtualLeafRecord(com.swirlds.virtualmap.datasource.VirtualLeafRecord) IOException(java.io.IOException)

Example 5 with ContractKey

use of com.hedera.services.state.virtual.ContractKey in project hedera-services by hashgraph.

the class VirtualDataSourceBench method setup.

@Setup(Level.Trial)
public void setup() throws IOException {
    random = new Random(1234);
    System.out.println("dataSourcePath = " + dataSourcePath);
    if (Files.exists(dataSourcePath)) {
        System.err.println("!!!!!!!!!!!!! Deleting old db.");
        deleteDirectoryAndContents(dataSourcePath);
    }
    if (Files.exists(dataSourceSnapshotPath)) {
        System.err.println("!!!!!!!!!!!!! Deleting old db snapshot.");
        deleteDirectoryAndContents(dataSourceSnapshotPath);
    }
    // create data source
    VirtualLeafRecordSerializer<ContractKey, ContractValue> virtualLeafRecordSerializer = new VirtualLeafRecordSerializer<>((short) 1, DigestType.SHA_384, (short) 1, DataFileCommon.VARIABLE_DATA_SIZE, new ContractKeySupplier(), (short) 1, ContractValue.SERIALIZED_SIZE, new ContractValueSupplier(), true);
    JasperDbBuilder<ContractKey, ContractValue> dbBuilder = new JasperDbBuilder<>();
    dbBuilder.virtualLeafRecordSerializer(virtualLeafRecordSerializer).virtualInternalRecordSerializer(new VirtualInternalRecordSerializer()).keySerializer(new ContractKeySerializer()).storageDir(dataSourcePath).maxNumOfKeys(500_000_000).preferDiskBasedIndexes(false).internalHashesRamToDiskThreshold(0).mergingEnabled(false);
    dataSource = dbBuilder.build("jdb", "4dsBench");
    // populate with initial data
    System.out.printf("Creating initial data set of %,d leaves\n", initialDataSize);
    progressPercentage = 0;
    final long firstLeafPath = initialDataSize;
    final long lastLeafPath = firstLeafPath + initialDataSize;
    var internalRecordStream = LongStream.range(0, firstLeafPath).mapToObj(path -> new VirtualInternalRecord(path, hash((int) path)));
    var leafRecordStream = LongStream.range(firstLeafPath, lastLeafPath + 1).mapToObj(path -> new VirtualLeafRecord<>(path, hash((int) path), new ContractKey(path, path), new ContractValue(path))).peek(leaf -> printProgress(leaf.getPath(), lastLeafPath));
    dataSource.saveRecords(firstLeafPath, lastLeafPath, internalRecordStream, leafRecordStream, Stream.empty());
    System.out.printf("Done creating initial data set of %,d leaves\n", initialDataSize);
}
Also used : ContractValueSupplier(com.hedera.services.state.virtual.ContractValueSupplier) BenchmarkMode(org.openjdk.jmh.annotations.BenchmarkMode) Measurement(org.openjdk.jmh.annotations.Measurement) JasperDbBuilder(com.swirlds.jasperdb.JasperDbBuilder) ContractKey(com.hedera.services.state.virtual.ContractKey) VirtualInternalRecordSerializer(com.swirlds.jasperdb.VirtualInternalRecordSerializer) CommonTestUtils.deleteDirectoryAndContents(utils.CommonTestUtils.deleteDirectoryAndContents) VirtualLeafRecordSerializer(com.swirlds.jasperdb.VirtualLeafRecordSerializer) DataFileCommon(com.swirlds.jasperdb.files.DataFileCommon) Scope(org.openjdk.jmh.annotations.Scope) Random(java.util.Random) ContractKeySupplier(com.hedera.services.state.virtual.ContractKeySupplier) Warmup(org.openjdk.jmh.annotations.Warmup) OutputTimeUnit(org.openjdk.jmh.annotations.OutputTimeUnit) VirtualLeafRecord(com.swirlds.virtualmap.datasource.VirtualLeafRecord) Path(java.nio.file.Path) CommonTestUtils.hash(utils.CommonTestUtils.hash) Setup(org.openjdk.jmh.annotations.Setup) LongStream(java.util.stream.LongStream) VirtualDataSourceJasperDB(com.swirlds.jasperdb.VirtualDataSourceJasperDB) Mode(org.openjdk.jmh.annotations.Mode) Files(java.nio.file.Files) ContractValue(com.hedera.services.state.virtual.ContractValue) Param(org.openjdk.jmh.annotations.Param) IOException(java.io.IOException) State(org.openjdk.jmh.annotations.State) DigestType(com.swirlds.common.crypto.DigestType) Benchmark(org.openjdk.jmh.annotations.Benchmark) TimeUnit(java.util.concurrent.TimeUnit) VirtualInternalRecord(com.swirlds.virtualmap.datasource.VirtualInternalRecord) Stream(java.util.stream.Stream) Level(org.openjdk.jmh.annotations.Level) Fork(org.openjdk.jmh.annotations.Fork) ContractKeySerializer(com.hedera.services.state.virtual.ContractKeySerializer) VirtualLeafRecordSerializer(com.swirlds.jasperdb.VirtualLeafRecordSerializer) JasperDbBuilder(com.swirlds.jasperdb.JasperDbBuilder) VirtualInternalRecord(com.swirlds.virtualmap.datasource.VirtualInternalRecord) ContractValue(com.hedera.services.state.virtual.ContractValue) Random(java.util.Random) ContractKey(com.hedera.services.state.virtual.ContractKey) ContractValueSupplier(com.hedera.services.state.virtual.ContractValueSupplier) VirtualInternalRecordSerializer(com.swirlds.jasperdb.VirtualInternalRecordSerializer) VirtualLeafRecord(com.swirlds.virtualmap.datasource.VirtualLeafRecord) ContractKeySerializer(com.hedera.services.state.virtual.ContractKeySerializer) ContractKeySupplier(com.hedera.services.state.virtual.ContractKeySupplier) Setup(org.openjdk.jmh.annotations.Setup)

Aggregations

ContractKey (com.hedera.services.state.virtual.ContractKey)14 ContractValue (com.hedera.services.state.virtual.ContractValue)13 ContractKeySupplier (com.hedera.services.state.virtual.ContractKeySupplier)8 ContractValueSupplier (com.hedera.services.state.virtual.ContractValueSupplier)8 VirtualLeafRecordSerializer (com.swirlds.jasperdb.VirtualLeafRecordSerializer)8 VirtualInternalRecord (com.swirlds.virtualmap.datasource.VirtualInternalRecord)8 Path (java.nio.file.Path)8 ContractKeySerializer (com.hedera.services.state.virtual.ContractKeySerializer)7 VirtualLeafRecord (com.swirlds.virtualmap.datasource.VirtualLeafRecord)7 IOException (java.io.IOException)7 DigestType (com.swirlds.common.crypto.DigestType)6 JasperDbBuilder (com.swirlds.jasperdb.JasperDbBuilder)6 VirtualInternalRecordSerializer (com.swirlds.jasperdb.VirtualInternalRecordSerializer)6 DataFileCommon (com.swirlds.jasperdb.files.DataFileCommon)6 Files (java.nio.file.Files)6 LongStream (java.util.stream.LongStream)6 VirtualDataSourceJasperDB (com.swirlds.jasperdb.VirtualDataSourceJasperDB)5 Random (java.util.Random)5 Stream (java.util.stream.Stream)5 Benchmark (org.openjdk.jmh.annotations.Benchmark)4