src/main/java/org/apache/flink/state/benchmark/HashMapStateBackendRescalingBenchmarkExecutor.java [60:78]:
- - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - -
                                        .createCheckpointStorage(new JobID()))
                        .setStateBackend(stateBackend)
                        .setStreamRecordGenerator(new ByteArrayRecordGenerator(numberOfKeys, keyLen))
                        .setStateProcessFunctionSupplier(TestKeyedFunction::new)
                        .build();
        benchmark.setUp();
    }

    @Setup(Level.Invocation)
    public void setUpPerInvocation() throws Exception {
        benchmark.prepareStateForOperator(rescaleType.getSubtaskIndex());
    }

    @TearDown(Level.Trial)
    public void tearDown() throws IOException {
        benchmark.tearDown();
    }

    @Benchmark
- - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - -



src/main/java/org/apache/flink/state/benchmark/RocksdbStateBackendRescalingBenchmarkExecutor.java [59:77]:
- - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - -
                                        .createCheckpointStorage(new JobID()))
                        .setStateBackend(stateBackend)
                        .setStreamRecordGenerator(new ByteArrayRecordGenerator(numberOfKeys, keyLen))
                        .setStateProcessFunctionSupplier(TestKeyedFunction::new)
                        .build();
        benchmark.setUp();
    }

    @Setup(Level.Invocation)
    public void setUpPerInvocation() throws Exception {
        benchmark.prepareStateForOperator(rescaleType.getSubtaskIndex());
    }

    @TearDown(Level.Trial)
    public void tearDown() throws IOException {
        benchmark.tearDown();
    }

    @Benchmark
- - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - - -



