|
Change Parameter Type storeFlusher : StoreFlusher to storageEngine : StorageEngine in method public DefaultRecoverySPI(storageEngine StorageEngine, logFileRecoverer Visitor<LogVersionedStoreChannel,Exception>, logFiles PhysicalLogFiles, fileSystemAbstraction FileSystemAbstraction, logVersionRepository LogVersionRepository, checkPointFinder LatestCheckPointFinder) in class org.neo4j.kernel.recovery.DefaultRecoverySPI |
From |
To |
|
Change Parameter Type storageEngine : StorageEngine to storageEngine : RecordStorageEngine in method public Worker(id int, end AtomicBoolean, storageEngine RecordStorageEngine, batchSize int, index IndexProxy) in class org.neo4j.kernel.impl.transaction.command.IndexWorkSyncTransactionApplicationStressIT.Worker |
From |
To |
|
Change Parameter Type commands : Collection<Command> to commands : Collection<StorageCommand> in method public serialize(commands Collection<StorageCommand>) : void in class org.neo4j.kernel.impl.transaction.log.entry.LogEntryWriter |
From |
To |
|
Change Parameter Type metaDataStore : MetaDataStore to transactionIdStore : TransactionIdStore in method public LastCommittedIndexFinder(transactionIdStore TransactionIdStore, transactionStore LogicalTransactionStore, logProvider LogProvider) in class org.neo4j.coreedge.raft.replication.tx.LastCommittedIndexFinder |
From |
To |
|
Change Parameter Type storeFlusher : StoreFlusher to storageEngine : StorageEngine in method public CheckPointerImpl(transactionIdStore TransactionIdStore, threshold CheckPointThreshold, storageEngine StorageEngine, logPruning LogPruning, appender TransactionAppender, databaseHealth DatabaseHealth, logProvider LogProvider, tracer CheckPointTracer) in class org.neo4j.kernel.impl.transaction.log.checkpoint.CheckPointerImpl |
From |
To |
|
Change Parameter Type neoStoreSupplier : Supplier<NeoStores> to txIdGetter : LastTxIdGetter in method private createKernelData(config Config, graphDb GraphDatabaseAPI, members ClusterMembers, fs FileSystemAbstraction, pageCache PageCache, storeDir File, lastUpdateTime LastUpdateTime, txIdGetter LastTxIdGetter, life LifeSupport) : KernelData in class org.neo4j.kernel.ha.factory.HighlyAvailableEditionModule |
From |
To |
|
Change Parameter Type neoStores : NeoStores to fullStoreStream : FullStoreChangeStream in method public LuceneLabelScanStoreBuilder(storeDir File, fullStoreStream FullStoreChangeStream, fileSystem FileSystemAbstraction, logProvider LogProvider) in class org.neo4j.index.lucene.LuceneLabelScanStoreBuilder |
From |
To |
|
Change Parameter Type dataSourceManager : DataSourceManager to transactionIdStore : Supplier<TransactionIdStore> in method public TransactionMetrics(registry MetricRegistry, transactionIdStore Supplier<TransactionIdStore>, transactionCounters TransactionCounters) in class org.neo4j.metrics.source.db.TransactionMetrics |
From |
To |
|
Change Parameter Type commands : Collection<Command> to commands : Collection<StorageCommand> in method public createCommandBytes(commands Collection<StorageCommand>) : byte[] in class org.neo4j.coreedge.raft.replication.token.ReplicatedTokenRequestSerializer |
From |
To |
|
Change Parameter Type neoStoresSupplier : Supplier<NeoStores> to txIdSupplier : LongSupplier in method public OnDiskLastTxIdGetter(txIdSupplier LongSupplier) in class org.neo4j.kernel.ha.transaction.OnDiskLastTxIdGetter |
From |
To |
|
Change Parameter Type storeFlusher : StoreFlusher to storageEngine : StorageEngine in method public CheckPointerImpl(transactionIdStore TransactionIdStore, threshold CheckPointThreshold, storageEngine StorageEngine, logPruning LogPruning, appender TransactionAppender, databaseHealth DatabaseHealth, logProvider LogProvider, tracer CheckPointTracer, lock Lock) in class org.neo4j.kernel.impl.transaction.log.checkpoint.CheckPointerImpl |
From |
To |
|
Change Parameter Type bridge : ThreadToStatementContextBridge to readOperations : ReadOperations in method private awaitOnline(db GraphDatabaseAPI, readOperations ReadOperations, index IndexDescriptor) : IndexDescriptor in class org.neo4j.storeupgrade.StoreUpgradeIntegrationTest |
From |
To |
|
Change Variable Type neoStores : NeoStores to txIdStore : TransactionIdStore in method public shouldIdentifyTransactionWithNetZeroChangesAsReadOnly() : void in class org.neo4j.kernel.impl.api.state.NoChangeWriteTransactionTest |
From |
To |
|
Change Variable Type storageEngine : StorageEngine to storageEngine : RecordStorageEngine in method public shouldApplyIndexUpdatesInWorkSyncedBatches() : void in class org.neo4j.kernel.impl.transaction.command.IndexWorkSyncTransactionApplicationStressIT |
From |
To |
|
Change Variable Type command : Command to command : StorageCommand in method public serialize(commands Collection<StorageCommand>) : void in class org.neo4j.kernel.impl.transaction.log.entry.LogEntryWriter |
From |
To |
|
Change Variable Type neoStoresSupplier : Supplier<NeoStores> to supplier : LongSupplier in method public lastTransactionIdIsBaseTxIdWhileNeoStoresAreStopped() : void in class org.neo4j.kernel.ha.OnDiskLastTxIdGetterTest |
From |
To |
|
Change Variable Type metaDataStore : MetaDataStore to transactionIdStore : TransactionIdStore in method public start() : void in class org.neo4j.coreedge.server.core.RecoverTransactionLogState |
From |
To |
|
Change Variable Type flusher : StoreFlusher to storageEngine : StorageEngine in method public shouldRecoverExistingData() : void in class org.neo4j.kernel.RecoveryTest |
From |
To |
|
Change Variable Type storeView : IndexStoreView to indexStoreView : NeoStoreIndexStoreView in method private repopulateAllIndexes() : void in class org.neo4j.unsafe.batchinsert.BatchInserterImpl |
From |
To |
|
Change Variable Type commands : ArrayList<Command> to commands : ArrayList<StorageCommand> in method public shouldMarshalTokenRequest() : void in class org.neo4j.coreedge.raft.replication.CoreReplicatedContentByteBufferMarshalTest |
From |
To |
|
Change Variable Type tokenId : long to tokenId : int in method private createCommands(tokenName String) : byte[] in class org.neo4j.coreedge.raft.replication.token.ReplicatedTokenHolder |
From |
To |
|
Change Variable Type soughtId : int to candidate : long in method private containsAnyLabel(labelIdFilter IntPredicate, labels long[]) : boolean in class org.neo4j.kernel.impl.transaction.state.NeoStoreIndexStoreView |
From |
To |
|
Change Variable Type bridge : ThreadToStatementContextBridge to kernel : KernelAPI in method private checkIndexCounts(store Store, db GraphDatabaseAPI) : void in class org.neo4j.storeupgrade.StoreUpgradeIntegrationTest |
From |
To |
|
Change Variable Type commands : Collection<Command> to commands : Collection<StorageCommand> in method private createCommands(tokenName String) : byte[] in class org.neo4j.coreedge.raft.replication.token.ReplicatedTokenHolder |
From |
To |
|
Change Variable Type neoStores : NeoStores to txIdStore : TransactionIdStore in method public shouldDetectNoChangesInCommitsAlsoForTheIndexes() : void in class org.neo4j.kernel.impl.api.state.NoChangeWriteTransactionTest |
From |
To |
|
Change Variable Type flusher : StoreFlusher to storageEngine : StorageEngine in method public shouldSeeThatACleanDatabaseShouldNotRequireRecovery() : void in class org.neo4j.kernel.RecoveryTest |
From |
To |
|
Change Variable Type commands : List<Command> to commands : List<StorageCommand> in method private createCommands(tokenId int) : List<StorageCommand> in class org.neo4j.coreedge.raft.replication.token.ReplicatedTokenHolderTest |
From |
To |
|
Change Variable Type supplier : NeoStoresSupplier to kernel : KernelAPI in method public mustMendDuplicatePropertiesWhenUpgradingFromVersion21() : void in class upgrade.StoreMigratorFrom21IT |
From |
To |
|
Change Variable Type neoStores : NeoStores to txIdStore : TransactionIdStore in method private checkProvidedParameters(store Store, db GraphDatabaseAPI) : void in class org.neo4j.storeupgrade.StoreUpgradeIntegrationTest |
From |
To |
|
Split Parameter storageEngine : StorageEngine to [logVersionRepository : LogVersionRepository, legacyIndexTransactionOrdering : SynchronizedArrayIdOrderingQueue, transactionIdStore : TransactionIdStore] in method private buildTransactionLogs(storeDir File, config Config, logProvider LogProvider, scheduler JobScheduler, fileSystemAbstraction FileSystemAbstraction, storageEngine StorageEngine, logEntryReader LogEntryReader<ReadableClosablePositionAwareChannel>, legacyIndexTransactionOrdering SynchronizedArrayIdOrderingQueue, transactionIdStore TransactionIdStore, logVersionRepository LogVersionRepository) : TransactionLogModule in class org.neo4j.kernel.NeoStoreDataSource |
From |
To |
|
Split Parameter neoStores : NeoStores to [transactionIdStore : TransactionIdStore, logVersionRepository : LogVersionRepository] in method private buildRecovery(fileSystemAbstraction FileSystemAbstraction, transactionIdStore TransactionIdStore, logVersionRepository LogVersionRepository, recoveryVisitorMonitor RecoveryVisitor.Monitor, recoveryMonitor Recovery.Monitor, logFiles PhysicalLogFiles, startupStatistics StartupStatisticsProvider, storageEngine StorageEngine, logEntryReader LogEntryReader<ReadableClosablePositionAwareChannel>) : void in class org.neo4j.kernel.NeoStoreDataSource |
From |
To |
|
Rename Variable metaDataStore : MetaDataStore to transactionIdStore : TransactionIdStore in method public start() : void in class org.neo4j.coreedge.server.core.RecoverTransactionLogState |
From |
To |
|
Rename Variable flusher : StoreFlusher to storageEngine : StorageEngine in method public shouldRecoverExistingData() : void in class org.neo4j.kernel.RecoveryTest |
From |
To |
|
Rename Variable supplier : NeoStoresSupplier to kernel : KernelAPI in method public mustMendDuplicatePropertiesWhenUpgradingFromVersion21() : void in class upgrade.StoreMigratorFrom21IT |
From |
To |
|
Rename Variable soughtId : int to candidate : long in method private containsAnyLabel(labelIdFilter IntPredicate, labels long[]) : boolean in class org.neo4j.kernel.impl.transaction.state.NeoStoreIndexStoreView |
From |
To |
|
Rename Variable neoStores : NeoStores to txIdStore : TransactionIdStore in method private checkProvidedParameters(store Store, db GraphDatabaseAPI) : void in class org.neo4j.storeupgrade.StoreUpgradeIntegrationTest |
From |
To |
|
Rename Variable bridge : ThreadToStatementContextBridge to kernel : KernelAPI in method private checkIndexCounts(store Store, db GraphDatabaseAPI) : void in class org.neo4j.storeupgrade.StoreUpgradeIntegrationTest |
From |
To |
|
Rename Variable neoStores : NeoStores to txIdStore : TransactionIdStore in method public shouldIdentifyTransactionWithNetZeroChangesAsReadOnly() : void in class org.neo4j.kernel.impl.api.state.NoChangeWriteTransactionTest |
From |
To |
|
Rename Variable neoStores : NeoStores to txIdStore : TransactionIdStore in method public shouldDetectNoChangesInCommitsAlsoForTheIndexes() : void in class org.neo4j.kernel.impl.api.state.NoChangeWriteTransactionTest |
From |
To |
|
Rename Variable neoStoresSupplier : Supplier<NeoStores> to supplier : LongSupplier in method public lastTransactionIdIsBaseTxIdWhileNeoStoresAreStopped() : void in class org.neo4j.kernel.ha.OnDiskLastTxIdGetterTest |
From |
To |
|
Rename Variable flusher : StoreFlusher to storageEngine : StorageEngine in method public shouldSeeThatACleanDatabaseShouldNotRequireRecovery() : void in class org.neo4j.kernel.RecoveryTest |
From |
To |
|
Rename Attribute dataSource : NeoStoreDataSource to labelScanStore : LabelScanStore in class org.neo4j.tools.rebuild.RebuildFromLogs.ConsistencyChecker |
From |
To |
|
Rename Attribute dataSourceManager : DataSourceManager to transactionIdStore : Supplier<TransactionIdStore> in class org.neo4j.metrics.source.db.TransactionMetrics |
From |
To |
|
Rename Attribute providerMap : DefaultSchemaIndexProviderMap to schemaIndexProviderMap : DefaultSchemaIndexProviderMap in class org.neo4j.kernel.impl.storageengine.impl.recordstorage.RecordStorageEngine |
From |
To |
|
Rename Attribute storeFlusher : StoreFlusher to storageEngine : StorageEngine in class org.neo4j.kernel.recovery.DefaultRecoverySPI |
From |
To |
|
Rename Attribute neoStoresSupplier : Supplier<NeoStores> to txIdSupplier : LongSupplier in class org.neo4j.kernel.ha.transaction.OnDiskLastTxIdGetter |
From |
To |
|
Rename Attribute flusher : StoreFlusher to storageEngine : StorageEngine in class org.neo4j.kernel.impl.transaction.log.checkpoint.CheckPointerImplTest |
From |
To |
|
Rename Attribute metaDataStore : MetaDataStore to transactionIdStore : TransactionIdStore in class org.neo4j.coreedge.raft.replication.tx.LastCommittedIndexFinder |
From |
To |
|
Rename Attribute ctxSupplier : ThreadToStatementContextBridge to kernel : KernelAPI in class org.neo4j.kernel.impl.api.index.IndexPopulationJobTest |
From |
To |
|
Rename Attribute storeFlusher : StoreFlusher to storageEngine : StorageEngine in class org.neo4j.kernel.impl.transaction.log.checkpoint.CheckPointerImpl |
From |
To |
|
Change Attribute Type ctxSupplier : ThreadToStatementContextBridge to kernel : KernelAPI in class org.neo4j.kernel.impl.api.index.IndexPopulationJobTest |
From |
To |
|
Change Attribute Type storeFlusher : StoreFlusher to storageEngine : StorageEngine in class org.neo4j.kernel.recovery.DefaultRecoverySPI |
From |
To |
|
Change Attribute Type storageEngine : StorageEngine to storageEngine : RecordStorageEngine in class org.neo4j.kernel.impl.transaction.command.IndexWorkSyncTransactionApplicationStressIT.Worker |
From |
To |
|
Change Attribute Type metaDataStore : MetaDataStore to transactionIdStore : TransactionIdStore in class org.neo4j.coreedge.raft.replication.tx.LastCommittedIndexFinder |
From |
To |
|
Change Attribute Type storeFlusher : StoreFlusher to storageEngine : StorageEngine in class org.neo4j.kernel.impl.transaction.log.checkpoint.CheckPointerImpl |
From |
To |
|
Change Attribute Type indexStoreView : NeoStoreIndexStoreView to indexStoreView : IndexStoreView in class org.neo4j.kernel.impl.api.index.IndexPopulationJobTest |
From |
To |
|
Change Attribute Type dataSource : NeoStoreDataSource to labelScanStore : LabelScanStore in class org.neo4j.tools.rebuild.RebuildFromLogs.ConsistencyChecker |
From |
To |
|
Change Attribute Type dataSourceManager : DataSourceManager to transactionIdStore : Supplier<TransactionIdStore> in class org.neo4j.metrics.source.db.TransactionMetrics |
From |
To |
|
Change Attribute Type counts : CountsAccessor to counts : CountsTracker in class org.neo4j.kernel.impl.api.store.DiskLayer |
From |
To |
|
Change Attribute Type disk : DiskLayer to disk : StoreReadLayer in class org.neo4j.kernel.impl.api.store.DiskLayerTest |
From |
To |
|
Change Attribute Type neoStoresSupplier : Supplier<NeoStores> to txIdSupplier : LongSupplier in class org.neo4j.kernel.ha.transaction.OnDiskLastTxIdGetter |
From |
To |
|
Change Attribute Type flusher : StoreFlusher to storageEngine : StorageEngine in class org.neo4j.kernel.impl.transaction.log.checkpoint.CheckPointerImplTest |
From |
To |
|
Rename Parameter storeFlusher : StoreFlusher to storageEngine : StorageEngine in method public DefaultRecoverySPI(storageEngine StorageEngine, logFileRecoverer Visitor<LogVersionedStoreChannel,Exception>, logFiles PhysicalLogFiles, fileSystemAbstraction FileSystemAbstraction, logVersionRepository LogVersionRepository, checkPointFinder LatestCheckPointFinder) in class org.neo4j.kernel.recovery.DefaultRecoverySPI |
From |
To |
|
Rename Parameter neoStores : NeoStores to fullStoreStream : FullStoreChangeStream in method public LuceneLabelScanStoreBuilder(storeDir File, fullStoreStream FullStoreChangeStream, fileSystem FileSystemAbstraction, logProvider LogProvider) in class org.neo4j.index.lucene.LuceneLabelScanStoreBuilder |
From |
To |
|
Rename Parameter dataSourceManager : DataSourceManager to transactionIdStore : Supplier<TransactionIdStore> in method public TransactionMetrics(registry MetricRegistry, transactionIdStore Supplier<TransactionIdStore>, transactionCounters TransactionCounters) in class org.neo4j.metrics.source.db.TransactionMetrics |
From |
To |
|
Rename Parameter metaDataStore : MetaDataStore to transactionIdStore : TransactionIdStore in method public LastCommittedIndexFinder(transactionIdStore TransactionIdStore, transactionStore LogicalTransactionStore, logProvider LogProvider) in class org.neo4j.coreedge.raft.replication.tx.LastCommittedIndexFinder |
From |
To |
|
Rename Parameter neoStoresSupplier : Supplier<NeoStores> to txIdSupplier : LongSupplier in method public OnDiskLastTxIdGetter(txIdSupplier LongSupplier) in class org.neo4j.kernel.ha.transaction.OnDiskLastTxIdGetter |
From |
To |
|
Rename Parameter storeFlusher : StoreFlusher to storageEngine : StorageEngine in method public CheckPointerImpl(transactionIdStore TransactionIdStore, threshold CheckPointThreshold, storageEngine StorageEngine, logPruning LogPruning, appender TransactionAppender, databaseHealth DatabaseHealth, logProvider LogProvider, tracer CheckPointTracer, lock Lock) in class org.neo4j.kernel.impl.transaction.log.checkpoint.CheckPointerImpl |
From |
To |
|
Rename Parameter storeFlusher : StoreFlusher to storageEngine : StorageEngine in method public CheckPointerImpl(transactionIdStore TransactionIdStore, threshold CheckPointThreshold, storageEngine StorageEngine, logPruning LogPruning, appender TransactionAppender, databaseHealth DatabaseHealth, logProvider LogProvider, tracer CheckPointTracer) in class org.neo4j.kernel.impl.transaction.log.checkpoint.CheckPointerImpl |
From |
To |
|
Rename Parameter bridge : ThreadToStatementContextBridge to readOperations : ReadOperations in method private awaitOnline(db GraphDatabaseAPI, readOperations ReadOperations, index IndexDescriptor) : IndexDescriptor in class org.neo4j.storeupgrade.StoreUpgradeIntegrationTest |
From |
To |
|
Rename Parameter neoStoreSupplier : Supplier<NeoStores> to txIdGetter : LastTxIdGetter in method private createKernelData(config Config, graphDb GraphDatabaseAPI, members ClusterMembers, fs FileSystemAbstraction, pageCache PageCache, storeDir File, lastUpdateTime LastUpdateTime, txIdGetter LastTxIdGetter, life LifeSupport) : KernelData in class org.neo4j.kernel.ha.factory.HighlyAvailableEditionModule |
From |
To |