|
Change Parameter Type neoStoreSupplier : Supplier<NeoStore> to neoStoresSupplier : Supplier<NeoStores> in method public OnDiskLastTxIdGetter(neoStoresSupplier Supplier<NeoStores>) in class org.neo4j.kernel.ha.transaction.OnDiskLastTxIdGetter |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public RecordChangeSet(neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.state.RecordChangeSet |
From |
To |
|
Change Parameter Type applier : NeoCommandHandler to applier : CommandHandler in method private apply(applier CommandHandler, transaction TransactionRepresentation) : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Parameter Type neoStore : BatchingNeoStore to neoStore : BatchingNeoStores in method public NodeStage(config Configuration, writeMonitor IoMonitor, nodes InputIterable<InputNode>, idMapper IdMapper, idGenerator IdGenerator, neoStore BatchingNeoStores, inputCache InputCache, labelScanStore LabelScanStore, storeUpdateMonitor EntityStoreUpdaterStep.Monitor, memoryUsage StatsProvider) in class org.neo4j.unsafe.impl.batchimport.NodeStage |
From |
To |
|
Change Parameter Type neostore : NeoStore to neoStores : NeoStores in method package emulateFailureOnRebuildOf(neoStores NeoStores) : void in class org.neo4j.kernel.impl.store.IdGeneratorRebuildFailureEmulationTest |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public handle(handler CommandHandler) : boolean in class org.neo4j.kernel.impl.transaction.command.Command.SchemaRuleCommand |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public StoreAbstractRelationshipCursor(relationshipRecord RelationshipRecord, neoStores NeoStores, storeStatement StoreStatement) in class org.neo4j.kernel.impl.api.store.StoreAbstractRelationshipCursor |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method private buildRecovery(fileSystemAbstraction FileSystemAbstraction, cacheAccess CacheAccessBackDoor, indexingService IndexingService, indexUpdatesValidator IndexUpdatesValidator, labelScanStore LabelScanStore, neoStores NeoStores, recoveryVisitorMonitor RecoveryVisitor.Monitor, recoveryMonitor Recovery.Monitor, logFiles PhysicalLogFiles, storeFlusher StoreFlusher, startupStatistics StartupStatisticsProvider) : void in class org.neo4j.kernel.NeoStoreDataSource |
From |
To |
|
Change Parameter Type delegate : NeoCommandHandler to delegate : CommandHandler in method public IndexCommandDetector(delegate CommandHandler) in class org.neo4j.kernel.impl.transaction.log.IndexCommandDetector |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method private alreadyContainsData(neoStores NeoStores) : boolean in class org.neo4j.unsafe.impl.batchimport.store.BatchingNeoStores |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public BatchRelationshipIterable(neoStores NeoStores, nodeId long) in class org.neo4j.unsafe.batchinsert.BatchRelationshipIterable |
From |
To |
|
Change Parameter Type visitor : NeoCommandHandler to visitor : CommandHandler in method public handle(visitor CommandHandler) : boolean in class org.neo4j.kernel.impl.index.IndexCommand.CreateCommand |
From |
To |
|
Change Parameter Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public RelationshipCountSampleable(neoStoresSupplier NeoStoresSupplier) in class org.neo4j.server.rrd.sampler.RelationshipCountSampleable |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public NeoStoreTransactionContextFactory(neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.state.NeoStoreTransactionContextFactory |
From |
To |
|
Change Parameter Type store : NeoStore to store : NeoStores in method private recordState(store NeoStores, context NeoStoreTransactionContext) : TransactionRecordState in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public CacheInvalidationTransactionApplier(delegate CommandHandler, neoStores NeoStores, cacheAccess CacheAccessBackDoor) in class org.neo4j.kernel.impl.transaction.command.CacheInvalidationTransactionApplier |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public NeoStoreTransactionContext(neoStores NeoStores, locks Client) in class org.neo4j.kernel.impl.transaction.state.NeoStoreTransactionContext |
From |
To |
|
Change Parameter Type visitor : NeoCommandHandler to visitor : CommandHandler in method public handle(visitor CommandHandler) : boolean in class org.neo4j.kernel.impl.index.IndexCommand.AddRelationshipCommand |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public StoreNodeRelationshipCursor(relationshipRecord RelationshipRecord, neoStores NeoStores, groupRecord RelationshipGroupRecord, storeStatement StoreStatement, instanceCache Consumer<StoreNodeRelationshipCursor>) in class org.neo4j.kernel.impl.api.store.StoreNodeRelationshipCursor |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public StoreIteratorRelationshipCursor(relationshipRecord RelationshipRecord, neoStores NeoStores, storeStatement StoreStatement, instanceCache InstanceCache<StoreIteratorRelationshipCursor>) in class org.neo4j.kernel.impl.api.store.StoreIteratorRelationshipCursor |
From |
To |
|
Change Parameter Type schemaStoreProvider : SchemaStoreProvider to storeFactory : StoreFactory in method public SchemaIndexMigrator(fileSystem FileSystemAbstraction, pageCache PageCache, upgradableDatabase UpgradableDatabase, storeFactory StoreFactory) in class org.neo4j.kernel.impl.storemigration.SchemaIndexMigrator |
From |
To |
|
Change Parameter Type transactionIdStore : TransactionIdStore to neoStores : NeoStores in method public StoreFlusher(neoStores NeoStores, indexingService IndexingService, labelScanStore LabelScanStore, indexProviders Iterable<IndexImplementation>) in class org.neo4j.kernel.impl.transaction.log.rotation.StoreFlusher |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public StoreStatement(neoStores NeoStores) in class org.neo4j.kernel.impl.api.store.StoreStatement |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method protected getStore(neoStores NeoStores) : PropertyStore in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest.PropertyStoreConsistentReadTest |
From |
To |
|
Change Parameter Type store : NeoStore to store : NeoStores in method private nodeWithDynamicLabelRecord(store NeoStores, nodeId AtomicLong, dynamicLabelRecordId AtomicLong) : TransactionRecordState in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public Tracker(neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.state.RelationshipCreatorTest.Tracker |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method private execute(cmd String, neoStores NeoStores) : boolean in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public handle(handler CommandHandler) : boolean in class org.neo4j.kernel.impl.transaction.command.Command.NodeCommand |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public IntegrityValidator(neoStores NeoStores, indexes IndexingService) in class org.neo4j.kernel.impl.transaction.state.IntegrityValidator |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public TransactionRecordState(neoStores NeoStores, integrityValidator IntegrityValidator, context NeoStoreTransactionContext) in class org.neo4j.kernel.impl.transaction.state.TransactionRecordState |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public abstract handle(handler CommandHandler) : boolean in class org.neo4j.kernel.impl.transaction.command.Command |
From |
To |
|
Change Parameter Type visitor : NeoCommandHandler to visitor : CommandHandler in method public handle(visitor CommandHandler) : boolean in class org.neo4j.kernel.impl.index.IndexDefineCommand |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public NeoStoreIndexStoreView(locks LockService, neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.state.NeoStoreIndexStoreView |
From |
To |
|
Change Parameter Type stores : NeoStore to stores : NeoStores in method public CountsComputer(stores NeoStores) in class org.neo4j.kernel.impl.store.CountsComputer |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method private buildStoreLayer(neoStores NeoStores, propertyKeyTokenHolder PropertyKeyTokenHolder, labelTokens LabelTokenHolder, relationshipTypeTokens RelationshipTypeTokenHolder, indexingService IndexingService, schemaCache SchemaCache, procedureCache ProcedureCache) : StoreLayerModule in class org.neo4j.kernel.NeoStoreDataSource |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method private buildKernel(integrityValidator IntegrityValidator, appender TransactionAppender, neoStores NeoStores, storeApplier TransactionRepresentationStoreApplier, indexingService IndexingService, indexUpdatesValidator IndexUpdatesValidator, storeLayer StoreReadLayer, updateableSchemaState UpdateableSchemaState, labelScanStore LabelScanStore, schemaIndexProviderMap SchemaIndexProviderMap, procedureCache ProcedureCache) : KernelModule in class org.neo4j.kernel.NeoStoreDataSource |
From |
To |
|
Change Parameter Type handlers : NeoCommandHandler... to handlers : CommandHandler... in method public CommandApplierFacade(handlers CommandHandler...) in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public HighIdTransactionApplier(delegate CommandHandler, neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.command.HighIdTransactionApplier |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public handle(handler CommandHandler) : boolean in class org.neo4j.kernel.impl.transaction.command.Command.LabelTokenCommand |
From |
To |
|
Change Parameter Type neoStore : BatchingNeoStore to neoStore : BatchingNeoStores in method public RelationshipStage(config Configuration, writeMonitor IoMonitor, relationships InputIterable<InputRelationship>, idMapper IdMapper, neoStore BatchingNeoStores, cache NodeRelationshipCache, specificIds boolean, storeUpdateMonitor EntityStoreUpdaterStep.Monitor) in class org.neo4j.unsafe.impl.batchimport.RelationshipStage |
From |
To |
|
Change Parameter Type command : Command.NeoStoreCommand to command : NeoStoreCommand in method public visitNeoStoreCommand(command NeoStoreCommand) : boolean in class org.neo4j.kernel.impl.transaction.command.CommandHandler |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method protected initialiseStore(neoStores NeoStores) : S in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public DirectRecordAccessSet(neoStores NeoStores) in class org.neo4j.unsafe.batchinsert.DirectRecordAccessSet |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method private getLogCursor(fname String, neoStores NeoStores) : IOCursor<LogEntry> in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public LuceneLabelScanStoreBuilder(storeDir File, neoStores NeoStores, fileSystem FileSystemAbstraction, logProvider LogProvider) in class org.neo4j.index.lucene.LuceneLabelScanStoreBuilder |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public KernelTransactions(neoStoreTransactionContextFactory NeoStoreTransactionContextFactory, neoStores NeoStores, locks Locks, integrityValidator IntegrityValidator, constraintIndexCreator ConstraintIndexCreator, indexingService IndexingService, labelScanStore LabelScanStore, statementOperations StatementOperationParts, updateableSchemaState UpdateableSchemaState, schemaWriteGuard SchemaWriteGuard, providerMap SchemaIndexProviderMap, txHeaderFactory TransactionHeaderInformationFactory, storeLayer StoreReadLayer, transactionCommitProcess TransactionCommitProcess, indexConfigStore IndexConfigStore, legacyIndexProviderLookup LegacyIndexProviderLookup, hooks TransactionHooks, constraintSemantics ConstraintSemantics, transactionMonitor TransactionMonitor, dataSourceLife LifeSupport, procedureCache ProcedureCache, tracers Tracers) in class org.neo4j.kernel.impl.api.KernelTransactions |
From |
To |
|
Change Parameter Type applier : NeoCommandHandler to applier : CommandHandler in method package RecoveryCommandHandler(name String, applier CommandHandler) in class org.neo4j.kernel.impl.api.RecoveryLegacyIndexApplierLookup.RecoveryCommandHandler |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public handle(handler CommandHandler) : boolean in class org.neo4j.kernel.impl.transaction.command.Command.RelationshipCountsCommand |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public handle(handler CommandHandler) : boolean in class org.neo4j.kernel.impl.transaction.command.Command.RelationshipGroupCommand |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method private listFiles(neoStores NeoStores) : void in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Change Parameter Type appliers : NeoCommandHandler... to appliers : CommandHandler... in method private applyAndClose(appliers CommandHandler...) : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Parameter Type store : NeoStore to store : NeoStores in method private deleteNode(store NeoStores, nodeId long) : TransactionRecordState in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method private read(cmd String, neoStores NeoStores) : void in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method private buildTransactionLogs(storeDir File, config Config, logProvider LogProvider, scheduler JobScheduler, labelScanStore LabelScanStore, fileSystemAbstraction FileSystemAbstraction, neoStores NeoStores, cacheAccess CacheAccessBackDoor, indexingService IndexingService, indexProviders Iterable<IndexImplementation>) : TransactionLogModule in class org.neo4j.kernel.NeoStoreDataSource |
From |
To |
|
Change Parameter Type store : NeoStore to store : NeoStores in method public NeoStoreTransactionApplier(store NeoStores, cacheAccess CacheAccessBackDoor, lockService LockService, lockGroup LockGroup, transactionId long) in class org.neo4j.kernel.impl.transaction.command.NeoStoreTransactionApplier |
From |
To |
|
Change Parameter Type store : NeoStore to store : NeoStores in method public StoreAccess(store NeoStores) in class org.neo4j.kernel.impl.store.StoreAccess |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public StoreAbstractNodeCursor(nodeRecord NodeRecord, neoStores NeoStores, storeStatement StoreStatement) in class org.neo4j.kernel.impl.api.store.StoreAbstractNodeCursor |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public handle(handler CommandHandler) : boolean in class org.neo4j.kernel.impl.transaction.command.Command.NeoStoreCommand |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public KernelTransactionImplementation(operations StatementOperationParts, schemaWriteGuard SchemaWriteGuard, labelScanStore LabelScanStore, indexService IndexingService, schemaState UpdateableSchemaState, recordState TransactionRecordState, providerMap SchemaIndexProviderMap, neoStores NeoStores, locks Locks.Client, hooks TransactionHooks, constraintIndexCreator ConstraintIndexCreator, headerInformationFactory TransactionHeaderInformationFactory, commitProcess TransactionCommitProcess, transactionMonitor TransactionMonitor, storeLayer StoreReadLayer, legacyIndexTransactionState LegacyIndexTransactionState, pool Pool<KernelTransactionImplementation>, constraintSemantics ConstraintSemantics, clock Clock, tracer TransactionTracer, procedureCache ProcedureCache) in class org.neo4j.kernel.impl.api.KernelTransactionImplementation |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method private getStore(fname String, neoStores NeoStores) : RecordStore in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Change Parameter Type delegate : NeoCommandHandler to delegate : CommandHandler in method public CacheInvalidationTransactionApplier(delegate CommandHandler, neoStores NeoStores, cacheAccess CacheAccessBackDoor) in class org.neo4j.kernel.impl.transaction.command.CacheInvalidationTransactionApplier |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public HandlerVisitor(handler CommandHandler) in class org.neo4j.kernel.impl.transaction.command.CommandHandler.HandlerVisitor |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method protected initialiseStore(neoStores NeoStores) : LabelTokenStore in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest.LabelTokenStoreConsistentReadTest |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method protected getStore(neoStores NeoStores) : LabelTokenStore in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest.LabelTokenStoreConsistentReadTest |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method private buildIndexing(config Config, scheduler JobScheduler, indexProvider SchemaIndexProvider, lockService LockService, tokenNameLookup TokenNameLookup, logProvider LogProvider, indexingServiceMonitor IndexingService.Monitor, neoStores NeoStores, updateableSchemaState UpdateableSchemaState) : IndexingModule in class org.neo4j.kernel.NeoStoreDataSource |
From |
To |
|
Change Parameter Type visitor : NeoCommandHandler to visitor : CommandHandler in method public handle(visitor CommandHandler) : boolean in class org.neo4j.kernel.impl.index.IndexCommand.DeleteCommand |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public TransactionRepresentationStoreApplier(indexingService IndexingService, labelScanWriters Provider<LabelScanWriter>, neoStores NeoStores, cacheAccess CacheAccessBackDoor, lockService LockService, legacyIndexProviderLookup LegacyIndexApplierLookup, indexConfigStore IndexConfigStore, health KernelHealth, legacyIndexTransactionOrdering IdOrderingQueue) in class org.neo4j.kernel.impl.api.TransactionRepresentationStoreApplier |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public IndexUpdatesValidator(neoStores NeoStores, kernelHealth KernelHealth, propertyLoader PropertyLoader, indexing IndexingService) in class org.neo4j.kernel.impl.api.index.IndexUpdatesValidator |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public handle(handler CommandHandler) : boolean in class org.neo4j.kernel.impl.transaction.command.Command.RelationshipCommand |
From |
To |
|
Change Parameter Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public DatabasePrimitivesSampleableBase(neoStoresSupplier NeoStoresSupplier) in class org.neo4j.server.rrd.sampler.DatabasePrimitivesSampleableBase |
From |
To |
|
Change Parameter Type store : NeoStore to store : NeoStores in method private assertDynamicLabelRecordInUse(store NeoStores, id long, inUse boolean) : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Parameter Type neoStore : NeoStore to metaDataStore : MetaDataStore in method private createTransactionAppender(metaDataStore MetaDataStore, transactionMetadataCache TransactionMetadataCache, legacyIndexTransactionOrdering IdOrderingQueue, logFile PhysicalLogFile, kernelHealth KernelHealth) : BatchingTransactionAppender in class org.neo4j.kernel.impl.api.TransactionRepresentationCommitProcessIT |
From |
To |
|
Change Parameter Type neoStoreSupplier : Supplier<NeoStore> to neoStoreSupplier : Supplier<NeoStores> in method protected createKernelData(config Config, graphDb GraphDatabaseAPI, members ClusterMembers, fs FileSystemAbstraction, pageCache PageCache, storeDir File, lastUpdateTime LastUpdateTime, neoStoreSupplier Supplier<NeoStores>) : KernelData in class org.neo4j.kernel.ha.factory.HighlyAvailableEditionModule |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public PropertyLoader(neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.state.PropertyLoader |
From |
To |
|
Change Parameter Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public fullStoreLabelUpdateStream(neoStoresSupplier NeoStoresSupplier) : FullStoreChangeStream in class org.neo4j.kernel.impl.api.scan.LabelScanStoreProvider |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public StoreSingleNodeCursor(nodeRecord NodeRecord, neoStores NeoStores, storeStatement StoreStatement, instanceCache Consumer<StoreSingleNodeCursor>) in class org.neo4j.kernel.impl.api.store.StoreSingleNodeCursor |
From |
To |
|
Change Parameter Type visitor : NeoCommandHandler to visitor : CommandHandler in method public handle(visitor CommandHandler) : boolean in class org.neo4j.kernel.impl.index.IndexCommand.RemoveCommand |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method protected getStore(neoStores NeoStores) : RelationshipStore in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest.RelationshipStoreConsistentReadTest |
From |
To |
|
Change Parameter Type visitor : NeoCommandHandler to visitor : CommandHandler in method public handle(visitor CommandHandler) : boolean in class org.neo4j.kernel.impl.index.IndexCommand.AddNodeCommand |
From |
To |
|
Change Parameter Type factory : StoreFactory to neoStores : NeoStores in method package DumpCountsStore(out PrintStream, neoStores NeoStores) in class org.neo4j.kernel.impl.store.counts.DumpCountsStore |
From |
To |
|
Change Parameter Type neoStore : NeoStore to metaDataStore : MetaDataStore in method private createCheckPointer(metaDataStore MetaDataStore, kernelHealth KernelHealth, appender TransactionAppender) : CheckPointerImpl in class org.neo4j.kernel.impl.api.TransactionRepresentationCommitProcessIT |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public handle(handler CommandHandler) : boolean in class org.neo4j.kernel.impl.transaction.command.Command.NodeCountsCommand |
From |
To |
|
Change Parameter Type commandWriter : NeoCommandHandler to commandWriter : CommandHandler in method public LogEntryWriter(channel WritableLogChannel, commandWriter CommandHandler) in class org.neo4j.kernel.impl.transaction.log.entry.LogEntryWriter |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public StoreIteratorNodeCursor(nodeRecord NodeRecord, neoStores NeoStores, storeStatement StoreStatement, instanceCache Consumer<StoreIteratorNodeCursor>) in class org.neo4j.kernel.impl.api.store.StoreIteratorNodeCursor |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public handle(handler CommandHandler) : boolean in class org.neo4j.kernel.impl.transaction.command.Command.PropertyCommand |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public handle(handler CommandHandler) : boolean in class org.neo4j.kernel.impl.transaction.command.Command.PropertyKeyTokenCommand |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method private interact(neoStores NeoStores) : void in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public RecordChangeSet(beforeStateForAll boolean, neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.state.RecordChangeSet |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public DiskLayer(propertyKeyTokenHolder PropertyKeyTokenHolder, labelTokenHolder LabelTokenHolder, relationshipTokenHolder RelationshipTypeTokenHolder, schemaStorage SchemaStorage, neoStores NeoStores, indexService IndexingService) in class org.neo4j.kernel.impl.api.store.DiskLayer |
From |
To |
|
Change Parameter Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public NodeIdsInUseSampleable(neoStoresSupplier NeoStoresSupplier) in class org.neo4j.server.rrd.sampler.NodeIdsInUseSampleable |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public TransactionalWorker(neoStores NeoStores, appender TransactionAppender, storeApplier TransactionRepresentationStoreApplier, completedLatch CountDownLatch) in class org.neo4j.kernel.impl.api.TransactionRepresentationCommitProcessIT.TransactionalWorker |
From |
To |
|
Change Parameter Type handler : NeoCommandHandler to handler : CommandHandler in method public handle(handler CommandHandler) : boolean in class org.neo4j.kernel.impl.transaction.command.Command.RelationshipTypeTokenCommand |
From |
To |
|
Change Parameter Type delegate : NeoCommandHandler to delegate : CommandHandler in method public HighIdTransactionApplier(delegate CommandHandler, neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.command.HighIdTransactionApplier |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method public StoreSingleRelationshipCursor(relationshipRecord RelationshipRecord, neoStores NeoStores, storeStatement StoreStatement, instanceCache InstanceCache<StoreSingleRelationshipCursor>) in class org.neo4j.kernel.impl.api.store.StoreSingleRelationshipCursor |
From |
To |
|
Change Parameter Type neoStore : NeoStore to neoStores : NeoStores in method protected getStore(neoStores NeoStores) : SchemaStore in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest.SchemaStoreConsistentReadTest |
From |
To |
|
Change Parameter Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public PropertyCountSampleable(neoStoresSupplier NeoStoresSupplier) in class org.neo4j.server.rrd.sampler.PropertyCountSampleable |
From |
To |
|
Change Parameter Type delegate : NeoCommandHandler to delegate : CommandHandler in method public Delegator(delegate CommandHandler) in class org.neo4j.kernel.impl.transaction.command.CommandHandler.Delegator |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyLabelTokenCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type mockStore : NeoStore to mockStore : NeoStores in method public shouldClearStateOnClose() : void in class org.neo4j.kernel.impl.transaction.state.RecordChangeSetTest |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitRelationshipCountsCommand(command RelationshipCountsCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type store : NeoStore to store : NeoStores in method public deletingNodeWithRelationshipsIsNotAllowed() : void in class org.neo4j.kernel.impl.transaction.state.IntegrityValidatorTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyNodeCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public before() : void in class org.neo4j.kernel.impl.api.store.DiskLayerTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldDeleteDynamicLabelsForDeletedNodeForRecoveredTransaction() : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyPropertyKeyTokenCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStore : NeoStores in method public idGeneratorsRebuildAfterRecovery() : void in class org.neo4j.kernel.RecoveryIT |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public shouldFindValidPreviousCommittedTxIdInFirstNeoStoreLog() : void in class org.neo4j.backup.BackupServiceIT |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyUpdateIndexRuleSchemaRuleCommandToTheStoreThrowingIndexProblem() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method private databaseWithManyPropertyKeys(propertyKeyCount int) : GraphDatabaseAPI in class org.neo4j.kernel.impl.core.ManyPropertyKeysIT |
From |
To |
|
Change Variable Type indexApplier : NeoCommandHandler to indexApplier : CommandHandler in method public shouldApplyDeleteIndexRuleSchemaRuleCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method private flushNeoStoreOnly() : void in class recovery.CountsStoreRecoveryTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldInvalidateTheCacheWhenTheNodeBecomesDense() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public verifyGroupIsDeletedWhenNeeded() : void in class org.neo4j.kernel.impl.store.RelationshipGroupStoreTest |
From |
To |
|
Change Variable Type indexApplier : NeoCommandHandler to indexApplier : CommandHandler in method public shouldApplyUpdateIndexRuleSchemaRuleCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method private initializeStores(storeDir File, additionalConfig Map<String,String>) : void in class org.neo4j.kernel.impl.store.NeoStoreTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyPropertyKeyTokenCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type reader : PhysicalLogNeoCommandReaderV2_2_4 to reader : PhysicalLogCommandReaderV2_2_4 in method public shouldProperlyMaskIndexIdFieldInIndexHeader() : void in class org.neo4j.kernel.impl.transaction.command.PhysicalLogNeoCommandReaderV2Test |
From |
To |
|
Change Variable Type neoStore : NeoStore to metaDataStore : MetaDataStore in method public shouldAddUpgradeFieldsToTheNeoStoreIfNotPresent() : void in class org.neo4j.kernel.impl.store.NeoStoreTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyCreateUniquenessConstraintRuleSchemaRuleCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyRelPropertyCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to metaDataStore : MetaDataStore in method private verifyNeoStore(neoStores NeoStores) : void in class upgrade.StoreMigratorFrom19IT |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public shouldExtractUpdateCommandsInCorrectOrder() : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method protected propertyStore() : PropertyStore in class org.neo4j.kernel.impl.AbstractNeo4jTestCase |
From |
To |
|
Change Variable Type actualApplier : NeoCommandHandler to actualApplier : CommandHandler in method public newApplier(name String, recovery boolean) : CommandHandler in class org.neo4j.kernel.impl.api.RecoveryLegacyIndexApplierLookup |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public mustReadExistingLightRecord() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Change Variable Type store : NeoStore to store : NeoStores in method public shouldValidateUniquenessIndexes() : void in class org.neo4j.kernel.impl.transaction.state.IntegrityValidatorTest |
From |
To |
|
Change Variable Type storeFactory : StoreFactory to neoStores : NeoStores in method private dumpFile(createStoreFactory Function<File,StoreFactory>, arg String) : void in class org.neo4j.kernel.impl.store.DumpStore |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyRelationshipGroupCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.DuplicatePropertyRemoverTest |
From |
To |
|
Change Variable Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public createRrdDbAndSampler(db Database, scheduler JobScheduler) : RrdDbWrapper in class org.neo4j.server.rrd.RrdFactory |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public setVersion() : void in class org.neo4j.kernel.impl.store.NeoStoreTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public forceReadingNonExistingRecordMustReturnEmptyRecordWithThatId() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.NonIndexedConflictResolverTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.IndexConsultedPropertyBlockSweeperTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method private applier(command IndexCommand) : CommandHandler in class org.neo4j.kernel.impl.api.LegacyIndexApplier |
From |
To |
|
Change Variable Type store : NeoStore to store : NeoStores in method public shouldDeleteDynamicLabelsForDeletedNode() : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitNodeCountsCommand(command NodeCountsCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldExtractDeleteCommandsInCorrectOrder() : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Variable Type indexApplier : NeoCommandHandler to indexApplier : CommandHandler in method public shouldApplyCreateIndexRuleSchemaRuleCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyRelationshipGroupCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyUpdateIndexRuleSchemaRuleCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitLabelTokenCommand(command LabelTokenCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyDeleteUniquenessConstraintRuleSchemaRuleCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type applierByIndex : Map<String,NeoCommandHandler> to applierByIndex : Map<String,CommandHandler> in method private applier(command IndexCommand) : CommandHandler in class org.neo4j.kernel.impl.api.LegacyIndexApplier |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyNeoStoreCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public checkingIfRecordIsInUseMustHappenAfterConsistentRead() : void in class org.neo4j.kernel.impl.store.RelationshipGroupStoreTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public testHonorsPassedInParams() : void in class org.neo4j.unsafe.batchinsert.BatchInserterImplTest |
From |
To |
|
Change Variable Type storeFactory : StoreFactory to createStoreFactory : Function<File,StoreFactory> in method public main(args String...) : void in class org.neo4j.kernel.impl.store.DumpStore |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public shouldMigrate() : void in class upgrade.StoreMigratorFrom20IT |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public shouldNotCreateSameLabelTwiceOnSameNode() : void in class org.neo4j.unsafe.batchinsert.BatchInsertTest |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitRelationshipTypeTokenCommand(command RelationshipTypeTokenCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyNeoStoreCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method private verifyImportedData(nodeData List<InputNode>, relationshipData List<InputRelationship>) : void in class org.neo4j.unsafe.impl.batchimport.input.csv.CsvInputBatchImportIT |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyCreateIndexRuleSchemaRuleCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyNodeCommandToTheStoreAndInvalidateTheCache() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public readingNonExistingLightRecordMustReturnNull() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyDeleteIndexRuleSchemaRuleCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public close() : void in class org.neo4j.kernel.impl.api.LegacyIndexApplier |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method private createAndVerify(customThreshold Integer) : void in class org.neo4j.kernel.impl.store.RelationshipGroupStoreTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public shouldIdentifyTransactionWithNetZeroChangesAsReadOnly() : void in class org.neo4j.kernel.impl.api.state.NoChangeWriteTransactionTest |
From |
To |
|
Change Variable Type supplier : NeoStoreSupplier to supplier : NeoStoresSupplier in method public testGetLastTxIdNoFilePresent() : void in class org.neo4j.kernel.ha.OnDiskLastTxIdGetterTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldDeleteDynamicLabelsForDeletedNode() : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method private nextId(clazz Class<?>) : long in class org.neo4j.kernel.impl.store.NeoStoreTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.DeferredIndexedConflictResolutionTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyNodeCommandToTheStoreInRecoveryMode() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitNeoStoreCommand(command NeoStoreCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public allStoresShouldHaveTheCurrentVersionIdentifier() : void in class org.neo4j.kernel.impl.store.StoreVersionTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public mustRetryInconsistentForcedReads() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyRelationshipCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public shouldDetectNoChangesInCommitsAlsoForTheIndexes() : void in class org.neo4j.kernel.impl.api.state.NoChangeWriteTransactionTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyRelationshipTypeTokenCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.IndexLookupTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyRelationshipTypeTokenCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitIndexAddNodeCommand(command AddNodeCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyDeleteIndexRuleSchemaRuleCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method private getHighIds(db GraphDatabaseAPI) : Map<IdType,Long> in class org.neo4j.kernel.impl.core.TestCrashWithRebuildSlow |
From |
To |
|
Change Variable Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.NonIndexedConflictResolverTest |
From |
To |
|
Change Variable Type supplier : NeoStoreSupplier to supplier : NeoStoresSupplier in method public mustMendDuplicatePropertiesWhenUpgradingFromVersion21() : void in class upgrade.StoreMigratorFrom21IT |
From |
To |
|
Change Variable Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.IndexConsultedPropertyBlockSweeperTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyUpdateIndexRuleSchemaRuleCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to metaDataStore : MetaDataStore in method public verifyNeoStore(neoStores NeoStores) : void in class upgrade.StoreMigratorFrom20IT |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public verifyRecordsForDenseNodeWithTwoRelTypes() : void in class org.neo4j.kernel.impl.store.RelationshipGroupStoreTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyRelPropertyCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldExtractUpdateCommandsInCorrectOrder() : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyRelationshipCommandToTheStoreAndInvalidateTheCache() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitRelationshipCommand(command RelationshipCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public readingNonExistingRecordMustThrow() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitIndexAddRelationshipCommand(command AddRelationshipCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitPropertyKeyTokenCommand(command PropertyKeyTokenCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public runFullConsistencyCheck(storeDir File, tuningConfiguration Config, progressFactory ProgressMonitorFactory, logProvider LogProvider, fileSystem FileSystemAbstraction, pageCache PageCache) : Result in class org.neo4j.consistency.ConsistencyCheckService |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitIndexDeleteCommand(command DeleteCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type handlerOption : Optional<NeoCommandHandler> to handlerOption : Optional<CommandHandler> in method private getCountsStoreApplier(transactionId long, mode TransactionApplicationMode) : CommandHandler in class org.neo4j.kernel.impl.api.TransactionRepresentationStoreApplier |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public upgradedNeoStoreShouldHaveNewUpgradeTimeAndUpgradeId() : void in class upgrade.StoreUpgraderTest |
From |
To |
|
Change Variable Type reader : PhysicalLogNeoCommandReaderV2_2_4 to reader : PhysicalLogCommandReaderV2_2_4 in method public shouldReadIndexCommandHeaderCorrectly() : void in class org.neo4j.kernel.impl.transaction.command.PhysicalLogNeoCommandReaderV2Test |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyNodePropertyCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type store : NeoStore to store : NeoStores in method public shouldDeleteDynamicLabelsForDeletedNodeForRecoveredTransaction() : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyRelationshipCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitRelationshipGroupCommand(command RelationshipGroupCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public shouldOnlyChangeLockedRecordsWhenUpgradingToDenseNode() : void in class org.neo4j.kernel.impl.transaction.state.RelationshipCreatorTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyCreateUniquenessConstraintRuleSchemaRuleCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyCreateIndexRuleSchemaRuleCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitIndexRemoveCommand(command RemoveCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitSchemaRuleCommand(command SchemaRuleCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public mustSplitUpRelationshipChainsWhenCreatingDenseNodes() : void in class org.neo4j.unsafe.batchinsert.BatchInsertTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method private createScannableStores(storeDir File, tuningConfiguration Config) : DirectStoreAccess in class org.neo4j.perftest.enterprise.ccheck.ConsistencyPerformanceCheck |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public mustRetryInconsistentLightReads() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public mustReadExistingRecord() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public verifyRecordsForDenseNodeWithOneRelType() : void in class org.neo4j.kernel.impl.store.RelationshipGroupStoreTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public neoStoreHasCorrectStoreVersionField() : void in class org.neo4j.kernel.impl.store.StoreVersionTest |
From |
To |
|
Change Variable Type reader : PhysicalLogNeoCommandReaderV2_2_4 to reader : PhysicalLogCommandReaderV2_2_4 in method public shouldReadNoKeyIdAsMinusOne() : void in class org.neo4j.kernel.impl.transaction.command.PhysicalLogNeoCommandReaderV2_2_4Test |
From |
To |
|
Change Variable Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.DeferredIndexedConflictResolutionTest |
From |
To |
|
Change Variable Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.IndexLookupTest |
From |
To |
|
Change Variable Type reader : PhysicalLogNeoCommandReaderV2_1 to reader : PhysicalLogCommandReaderV2_1 in method public shouldReadPropertyCommandWithDeletedDynamicRecords() : void in class org.neo4j.kernel.impl.transaction.command.PhysicalLogNeoCommandReaderV1Test |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitIndexCreateCommand(command CreateCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public shouldMigrate() : void in class upgrade.StoreMigratorFrom19IT |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method private verifyDenseRepresentation(db GraphDatabaseService, node Node, dense boolean) : void in class upgrade.TestMigrateToDenseNodeSupport |
From |
To |
|
Change Variable Type neoStore : BatchingNeoStore to neoStore : BatchingNeoStores in method public doImport(input Input) : void in class org.neo4j.unsafe.impl.batchimport.ParallelBatchImporter |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyLabelTokenCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyNodePropertyCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type storeApplier : NeoCommandHandler to storeApplier : CommandHandler in method public apply(representation TransactionRepresentation, indexUpdates ValidatedIndexUpdates, locks LockGroup, transactionId long, mode TransactionApplicationMode) : void in class org.neo4j.kernel.impl.api.TransactionRepresentationStoreApplier |
From |
To |
|
Change Variable Type store : NeoStore to store : NeoStores in method public transactionsStartedBeforeAConstraintWasCreatedAreDisallowed() : void in class org.neo4j.kernel.impl.transaction.state.IntegrityValidatorTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method private applyAndClose(appliers CommandHandler...) : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyDeleteUniquenessConstraintRuleSchemaRuleCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type indexApplier : NeoCommandHandler to indexApplier : CommandHandler in method public shouldApplyUpdateIndexRuleSchemaRuleCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type countsStoreApplier : NeoCommandHandler to countsStoreApplier : CommandHandler in method public apply(representation TransactionRepresentation, indexUpdates ValidatedIndexUpdates, locks LockGroup, transactionId long, mode TransactionApplicationMode) : void in class org.neo4j.kernel.impl.api.TransactionRepresentationStoreApplier |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public mustRetryInconsistentReads() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public apply() : void in class org.neo4j.kernel.impl.api.LegacyIndexApplier |
From |
To |
|
Change Variable Type store : NeoStore to store : NeoStores in method public mustMendDuplicatePropertiesWhenUpgradingFromVersion21() : void in class upgrade.StoreMigratorFrom21IT |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyUpdateUniquenessConstraintRuleSchemaRuleCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public firstRecordOtherThanZeroIfNotFirst() : void in class org.neo4j.kernel.impl.store.TestGraphProperties |
From |
To |
|
Change Variable Type indexApplier : NeoCommandHandler to indexApplier : CommandHandler in method public shouldApplyCreateIndexRuleSchemaRuleCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type indexApplier : NeoCommandHandler to indexApplier : CommandHandler in method public shouldApplyDeleteIndexRuleSchemaRuleCommandToTheStoreInRecovery() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public mustSplitUpRelationshipChainsWhenCreatingDenseNodes() : void in class org.neo4j.unsafe.batchinsert.BatchInsertTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public shouldExtractDeleteCommandsInCorrectOrder() : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public main(args String[]) : void in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method private newApplier(recovery boolean) : CommandHandler in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method private checkProvidedParameters(store Store, db GraphDatabaseAPI) : void in class org.neo4j.storeupgrade.StoreUpgradeIntegrationTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public shouldExtractCreatedCommandsInCorrectOrder() : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitPropertyCommand(command PropertyCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitIndexDefineCommand(command IndexDefineCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type neostore : NeoStore to neoStores : NeoStores in method private performTest() : void in class org.neo4j.kernel.impl.store.IdGeneratorRebuildFailureEmulationTest |
From |
To |
|
Change Variable Type handler : NeoCommandHandler to handler : CommandHandler in method public visitNodeCommand(command NodeCommand) : boolean in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.DuplicatePropertyRemoverTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method private storeFixture() : NeoStores in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Change Variable Type mockStore : NeoStore to mockStore : NeoStores in method public mockNeoStores() : NeoStores in class org.neo4j.kernel.impl.store.NeoStoresMocking |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public shouldCreateConsistentUniquenessConstraint() : void in class org.neo4j.unsafe.batchinsert.BatchInsertTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public shouldSortLabelIdsWhenGetOrCreate() : void in class org.neo4j.unsafe.batchinsert.BatchInsertTest |
From |
To |
|
Change Variable Type applier : NeoCommandHandler to applier : CommandHandler in method public shouldApplyUpdateUniquenessConstraintRuleSchemaRuleCommandToTheStore() : void in class org.neo4j.kernel.impl.transaction.command.NeoTransactionStoreApplierTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to metaDataStore : MetaDataStore in method public shouldNotReadNonRecordDataAsRecord() : void in class org.neo4j.kernel.impl.store.NeoStoreTest |
From |
To |
|
Change Variable Type neoStore : NeoStore to neoStores : NeoStores in method public mustForceReadExistingRecord() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public before() : void in class org.neo4j.kernel.impl.api.store.DiskLayerTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public shouldExtractCreatedCommandsInCorrectOrder() : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public shouldMigrate() : void in class upgrade.StoreMigratorFrom19IT |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.DuplicatePropertyRemoverTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public setVersion() : void in class org.neo4j.kernel.impl.store.NeoStoreTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.NonIndexedConflictResolverTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.IndexConsultedPropertyBlockSweeperTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public firstRecordOtherThanZeroIfNotFirst() : void in class org.neo4j.kernel.impl.store.TestGraphProperties |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public mustForceReadExistingRecord() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Rename Variable file : PagedFile to ignore : PagedFile in method private storeExists(pageCache PageCache, targetStoreFileName File) : boolean in class org.neo4j.kernel.impl.storemigration.StoreFile |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method private createAndVerify(customThreshold Integer) : void in class org.neo4j.kernel.impl.store.RelationshipGroupStoreTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method private initializeStores(storeDir File, additionalConfig Map<String,String>) : void in class org.neo4j.kernel.impl.store.NeoStoreTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public mustSplitUpRelationshipChainsWhenCreatingDenseNodes() : void in class org.neo4j.unsafe.batchinsert.BatchInsertTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public shouldIdentifyTransactionWithNetZeroChangesAsReadOnly() : void in class org.neo4j.kernel.impl.api.state.NoChangeWriteTransactionTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public mustReadExistingRecord() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Rename Variable neoStore : NeoStore to metaDataStore : MetaDataStore in method public shouldAddUpgradeFieldsToTheNeoStoreIfNotPresent() : void in class org.neo4j.kernel.impl.store.NeoStoreTest |
From |
To |
|
Rename Variable neoStore : NeoStore to metaDataStore : MetaDataStore in method private verifyNeoStore(neoStores NeoStores) : void in class upgrade.StoreMigratorFrom19IT |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public shouldExtractUpdateCommandsInCorrectOrder() : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public neoStoreHasCorrectStoreVersionField() : void in class org.neo4j.kernel.impl.store.StoreVersionTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public checkingIfRecordIsInUseMustHappenAfterConsistentRead() : void in class org.neo4j.kernel.impl.store.RelationshipGroupStoreTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method private nextId(clazz Class<?>) : long in class org.neo4j.kernel.impl.store.NeoStoreTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.DeferredIndexedConflictResolutionTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public testHonorsPassedInParams() : void in class org.neo4j.unsafe.batchinsert.BatchInserterImplTest |
From |
To |
|
Rename Variable storeFactory : StoreFactory to createStoreFactory : Function<File,StoreFactory> in method public main(args String...) : void in class org.neo4j.kernel.impl.store.DumpStore |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public mustRetryInconsistentForcedReads() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public shouldMigrate() : void in class upgrade.StoreMigratorFrom20IT |
From |
To |
|
Rename Variable neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.IndexLookupTest |
From |
To |
|
Rename Variable neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public createRrdDbAndSampler(db Database, scheduler JobScheduler) : RrdDbWrapper in class org.neo4j.server.rrd.RrdFactory |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public shouldSortLabelIdsWhenGetOrCreate() : void in class org.neo4j.unsafe.batchinsert.BatchInsertTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method private getHighIds(db GraphDatabaseAPI) : Map<IdType,Long> in class org.neo4j.kernel.impl.core.TestCrashWithRebuildSlow |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method private verifyImportedData(nodeData List<InputNode>, relationshipData List<InputRelationship>) : void in class org.neo4j.unsafe.impl.batchimport.input.csv.CsvInputBatchImportIT |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public shouldOnlyChangeLockedRecordsWhenUpgradingToDenseNode() : void in class org.neo4j.kernel.impl.transaction.state.RelationshipCreatorTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public verifyGroupIsDeletedWhenNeeded() : void in class org.neo4j.kernel.impl.store.RelationshipGroupStoreTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method private createScannableStores(storeDir File, tuningConfiguration Config) : DirectStoreAccess in class org.neo4j.perftest.enterprise.ccheck.ConsistencyPerformanceCheck |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public mustRetryInconsistentLightReads() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method protected propertyStore() : PropertyStore in class org.neo4j.kernel.impl.AbstractNeo4jTestCase |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public mustReadExistingLightRecord() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public mustRetryInconsistentReads() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public upgradedNeoStoreShouldHaveNewUpgradeTimeAndUpgradeId() : void in class upgrade.StoreUpgraderTest |
From |
To |
|
Rename Variable storeFactory : StoreFactory to neoStores : NeoStores in method private dumpFile(createStoreFactory Function<File,StoreFactory>, arg String) : void in class org.neo4j.kernel.impl.store.DumpStore |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public allStoresShouldHaveTheCurrentVersionIdentifier() : void in class org.neo4j.kernel.impl.store.StoreVersionTest |
From |
To |
|
Rename Variable trailerOffset : long to trailerPosition : long in method private verifyRecordAlignmentAndRemoveTrailer() : void in class org.neo4j.kernel.impl.store.CommonAbstractStore |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public shouldNotCreateSameLabelTwiceOnSameNode() : void in class org.neo4j.unsafe.batchinsert.BatchInsertTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method private checkProvidedParameters(store Store, db GraphDatabaseAPI) : void in class org.neo4j.storeupgrade.StoreUpgradeIntegrationTest |
From |
To |
|
Rename Variable neostore : NeoStore to neoStores : NeoStores in method private performTest() : void in class org.neo4j.kernel.impl.store.IdGeneratorRebuildFailureEmulationTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method private verifyDenseRepresentation(db GraphDatabaseService, node Node, dense boolean) : void in class upgrade.TestMigrateToDenseNodeSupport |
From |
To |
|
Rename Variable neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.DuplicatePropertyRemoverTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public shouldCreateConsistentUniquenessConstraint() : void in class org.neo4j.unsafe.batchinsert.BatchInsertTest |
From |
To |
|
Rename Variable neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.IndexConsultedPropertyBlockSweeperTest |
From |
To |
|
Rename Variable neoStore : NeoStore to metaDataStore : MetaDataStore in method public shouldNotReadNonRecordDataAsRecord() : void in class org.neo4j.kernel.impl.store.NeoStoreTest |
From |
To |
|
Rename Variable neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.NonIndexedConflictResolverTest |
From |
To |
|
Rename Variable neoStore : NeoStore to metaDataStore : MetaDataStore in method public verifyNeoStore(neoStores NeoStores) : void in class upgrade.StoreMigratorFrom20IT |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public verifyRecordsForDenseNodeWithTwoRelTypes() : void in class org.neo4j.kernel.impl.store.RelationshipGroupStoreTest |
From |
To |
|
Rename Variable neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public mustSplitUpRelationshipChainsWhenCreatingDenseNodes() : void in class org.neo4j.unsafe.batchinsert.BatchInsertTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public readingNonExistingRecordMustThrow() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public shouldExtractDeleteCommandsInCorrectOrder() : void in class org.neo4j.kernel.impl.transaction.state.TransactionRecordStateTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public main(args String[]) : void in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public verifyRecordsForDenseNodeWithOneRelType() : void in class org.neo4j.kernel.impl.store.RelationshipGroupStoreTest |
From |
To |
|
Rename Variable neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.DeferredIndexedConflictResolutionTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public setUp() : void in class org.neo4j.kernel.impl.storemigration.legacystore.v21.propertydeduplication.IndexLookupTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public shouldDetectNoChangesInCommitsAlsoForTheIndexes() : void in class org.neo4j.kernel.impl.api.state.NoChangeWriteTransactionTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public shouldFindValidPreviousCommittedTxIdInFirstNeoStoreLog() : void in class org.neo4j.backup.BackupServiceIT |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method private storeFixture() : NeoStores in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public forceReadingNonExistingRecordMustReturnEmptyRecordWithThatId() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method private databaseWithManyPropertyKeys(propertyKeyCount int) : GraphDatabaseAPI in class org.neo4j.kernel.impl.core.ManyPropertyKeysIT |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public readingNonExistingLightRecordMustReturnNull() : void in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method private flushNeoStoreOnly() : void in class recovery.CountsStoreRecoveryTest |
From |
To |
|
Rename Variable neoStore : NeoStore to neoStores : NeoStores in method public runFullConsistencyCheck(storeDir File, tuningConfiguration Config, progressFactory ProgressMonitorFactory, logProvider LogProvider, fileSystem FileSystemAbstraction, pageCache PageCache) : Result in class org.neo4j.consistency.ConsistencyCheckService |
From |
To |
|
Change Attribute Type store : NeoStore to store : NeoStores in class org.neo4j.kernel.impl.transaction.state.WriteTransactionCommandOrderingTest |
From |
To |
|
Change Attribute Type neoStoreSupplier : Supplier<NeoStore> to neoStoresSupplier : Supplier<NeoStores> in class org.neo4j.kernel.ha.transaction.OnDiskLastTxIdGetter |
From |
To |
|
Change Attribute Type applierByRelationshipIndex : Map<String,NeoCommandHandler> to applierByRelationshipIndex : Map<String,CommandHandler> in class org.neo4j.kernel.impl.api.LegacyIndexApplier |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.command.NeoStoreTransactionApplier |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.api.TransactionRepresentationStoreApplier |
From |
To |
|
Change Attribute Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in class org.neo4j.index.lucene.LuceneLabelScanStoreBuilder |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.api.TransactionRepresentationCommitProcessIT |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.api.TransactionRepresentationStoreApplierTest |
From |
To |
|
Change Attribute Type schemaStoreProvider : SchemaStoreProvider to storeFactory : StoreFactory in class org.neo4j.kernel.impl.storemigration.SchemaIndexMigrator |
From |
To |
|
Change Attribute Type NO_APPLIER : NeoCommandHandler to NO_APPLIER : CommandHandler in class org.neo4j.kernel.impl.index.DummyIndexImplementation |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.state.NeoStoreTransactionTest |
From |
To |
|
Change Attribute Type applierByNodeIndex : Map<String,NeoCommandHandler> to applierByNodeIndex : Map<String,CommandHandler> in class org.neo4j.kernel.impl.api.LegacyIndexApplier |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.state.ApplyRecoveredTransactionsTest |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.command.HighIdTransactionApplier |
From |
To |
|
Change Attribute Type delegate : NeoCommandHandler to delegate : CommandHandler in class org.neo4j.kernel.impl.transaction.command.CommandHandler.Delegator |
From |
To |
|
Change Attribute Type neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in class org.neo4j.server.rrd.sampler.DatabasePrimitivesSampleableBase |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.state.PropertyLoader |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.api.store.DiskLayer |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.state.TransactionRecordState |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.state.PropertyLoaderTest |
From |
To |
|
Change Attribute Type handlers : NeoCommandHandler[] to handlers : CommandHandler[] in class org.neo4j.kernel.impl.api.CommandApplierFacade |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.state.NeoStoreTransactionContext |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.api.KernelTransactions |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.unsafe.batchinsert.BatchInserterImpl |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.store.StoreFactoryTest |
From |
To |
|
Change Attribute Type applierByProvider : Map<String,NeoCommandHandler> to applierByProvider : Map<String,CommandHandler> in class org.neo4j.kernel.impl.api.LegacyIndexApplier |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.api.store.StoreStatement |
From |
To |
|
Change Attribute Type delegate : NeoCommandHandler to delegate : CommandHandler in class org.neo4j.kernel.impl.transaction.command.HighIdTransactionApplier |
From |
To |
|
Change Attribute Type transactionIdStore : TransactionIdStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.log.rotation.StoreFlusher |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.state.SchemaRuleCommandTest |
From |
To |
|
Change Attribute Type FACTORY : Function<CountsAccessor.Updater,NeoCommandHandler> to FACTORY : Function<CountsAccessor.Updater,CommandHandler> in class org.neo4j.kernel.impl.api.CountsStoreApplier |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.api.store.StoreAbstractNodeCursor |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.store.StoreAccess |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.api.TransactionRepresentationCommitProcessIT.TransactionalWorker |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.state.NeoStoreTransactionContextFactory |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.unsafe.impl.batchimport.store.BatchingNeoStores |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.state.IntegrityValidator |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.api.store.StoreAbstractRelationshipCursor |
From |
To |
|
Change Attribute Type handler : NeoCommandHandler to handler : CommandHandler in class org.neo4j.kernel.impl.transaction.command.CommandHandler.HandlerVisitor |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.unsafe.impl.batchimport.PropertyEncoderStepTest |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.api.index.IndexUpdatesValidatorTest |
From |
To |
|
Change Attribute Type neoStore : NeoStore to neoStores : NeoStores in class org.neo4j.kernel.impl.transaction.state.NeoStoreIndexStoreViewTest |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public NeoStoreTransactionContextFactory(neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.state.NeoStoreTransactionContextFactory |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public CacheInvalidationTransactionApplier(delegate CommandHandler, neoStores NeoStores, cacheAccess CacheAccessBackDoor) in class org.neo4j.kernel.impl.transaction.command.CacheInvalidationTransactionApplier |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public KernelTransactions(neoStoreTransactionContextFactory NeoStoreTransactionContextFactory, neoStores NeoStores, locks Locks, integrityValidator IntegrityValidator, constraintIndexCreator ConstraintIndexCreator, indexingService IndexingService, labelScanStore LabelScanStore, statementOperations StatementOperationParts, updateableSchemaState UpdateableSchemaState, schemaWriteGuard SchemaWriteGuard, providerMap SchemaIndexProviderMap, txHeaderFactory TransactionHeaderInformationFactory, storeLayer StoreReadLayer, transactionCommitProcess TransactionCommitProcess, indexConfigStore IndexConfigStore, legacyIndexProviderLookup LegacyIndexProviderLookup, hooks TransactionHooks, constraintSemantics ConstraintSemantics, transactionMonitor TransactionMonitor, dataSourceLife LifeSupport, procedureCache ProcedureCache, tracers Tracers) in class org.neo4j.kernel.impl.api.KernelTransactions |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public NeoStoreTransactionContext(neoStores NeoStores, locks Client) in class org.neo4j.kernel.impl.transaction.state.NeoStoreTransactionContext |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public IntegrityValidator(neoStores NeoStores, indexes IndexingService) in class org.neo4j.kernel.impl.transaction.state.IntegrityValidator |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public StoreIteratorRelationshipCursor(relationshipRecord RelationshipRecord, neoStores NeoStores, storeStatement StoreStatement, instanceCache InstanceCache<StoreIteratorRelationshipCursor>) in class org.neo4j.kernel.impl.api.store.StoreIteratorRelationshipCursor |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method private buildRecovery(fileSystemAbstraction FileSystemAbstraction, cacheAccess CacheAccessBackDoor, indexingService IndexingService, indexUpdatesValidator IndexUpdatesValidator, labelScanStore LabelScanStore, neoStores NeoStores, recoveryVisitorMonitor RecoveryVisitor.Monitor, recoveryMonitor Recovery.Monitor, logFiles PhysicalLogFiles, storeFlusher StoreFlusher, startupStatistics StartupStatisticsProvider) : void in class org.neo4j.kernel.NeoStoreDataSource |
From |
To |
|
Rename Parameter neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public RelationshipCountSampleable(neoStoresSupplier NeoStoresSupplier) in class org.neo4j.server.rrd.sampler.RelationshipCountSampleable |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method protected initialiseStore(neoStores NeoStores) : S in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public DirectRecordAccessSet(neoStores NeoStores) in class org.neo4j.unsafe.batchinsert.DirectRecordAccessSet |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method protected getStore(neoStores NeoStores) : LabelTokenStore in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest.LabelTokenStoreConsistentReadTest |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public LuceneLabelScanStoreBuilder(storeDir File, neoStores NeoStores, fileSystem FileSystemAbstraction, logProvider LogProvider) in class org.neo4j.index.lucene.LuceneLabelScanStoreBuilder |
From |
To |
|
Rename Parameter neoStoreSupplier : Supplier<NeoStore> to neoStoresSupplier : Supplier<NeoStores> in method public OnDiskLastTxIdGetter(neoStoresSupplier Supplier<NeoStores>) in class org.neo4j.kernel.ha.transaction.OnDiskLastTxIdGetter |
From |
To |
|
Rename Parameter schemaStoreProvider : SchemaStoreProvider to storeFactory : StoreFactory in method public SchemaIndexMigrator(fileSystem FileSystemAbstraction, pageCache PageCache, upgradableDatabase UpgradableDatabase, storeFactory StoreFactory) in class org.neo4j.kernel.impl.storemigration.SchemaIndexMigrator |
From |
To |
|
Rename Parameter toAppend : String to substoreName : String in method private getStoreFileName(substoreName String) : File in class org.neo4j.kernel.impl.store.NeoStores |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public StoreIteratorNodeCursor(nodeRecord NodeRecord, neoStores NeoStores, storeStatement StoreStatement, instanceCache Consumer<StoreIteratorNodeCursor>) in class org.neo4j.kernel.impl.api.store.StoreIteratorNodeCursor |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public RecordChangeSet(neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.state.RecordChangeSet |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public DiskLayer(propertyKeyTokenHolder PropertyKeyTokenHolder, labelTokenHolder LabelTokenHolder, relationshipTokenHolder RelationshipTypeTokenHolder, schemaStorage SchemaStorage, neoStores NeoStores, indexService IndexingService) in class org.neo4j.kernel.impl.api.store.DiskLayer |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public KernelTransactionImplementation(operations StatementOperationParts, schemaWriteGuard SchemaWriteGuard, labelScanStore LabelScanStore, indexService IndexingService, schemaState UpdateableSchemaState, recordState TransactionRecordState, providerMap SchemaIndexProviderMap, neoStores NeoStores, locks Locks.Client, hooks TransactionHooks, constraintIndexCreator ConstraintIndexCreator, headerInformationFactory TransactionHeaderInformationFactory, commitProcess TransactionCommitProcess, transactionMonitor TransactionMonitor, storeLayer StoreReadLayer, legacyIndexTransactionState LegacyIndexTransactionState, pool Pool<KernelTransactionImplementation>, constraintSemantics ConstraintSemantics, clock Clock, tracer TransactionTracer, procedureCache ProcedureCache) in class org.neo4j.kernel.impl.api.KernelTransactionImplementation |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method private buildKernel(integrityValidator IntegrityValidator, appender TransactionAppender, neoStores NeoStores, storeApplier TransactionRepresentationStoreApplier, indexingService IndexingService, indexUpdatesValidator IndexUpdatesValidator, storeLayer StoreReadLayer, updateableSchemaState UpdateableSchemaState, labelScanStore LabelScanStore, schemaIndexProviderMap SchemaIndexProviderMap, procedureCache ProcedureCache) : KernelModule in class org.neo4j.kernel.NeoStoreDataSource |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public StoreSingleRelationshipCursor(relationshipRecord RelationshipRecord, neoStores NeoStores, storeStatement StoreStatement, instanceCache InstanceCache<StoreSingleRelationshipCursor>) in class org.neo4j.kernel.impl.api.store.StoreSingleRelationshipCursor |
From |
To |
|
Rename Parameter neoStore : NeoStore to metaDataStore : MetaDataStore in method private createTransactionAppender(metaDataStore MetaDataStore, transactionMetadataCache TransactionMetadataCache, legacyIndexTransactionOrdering IdOrderingQueue, logFile PhysicalLogFile, kernelHealth KernelHealth) : BatchingTransactionAppender in class org.neo4j.kernel.impl.api.TransactionRepresentationCommitProcessIT |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method private execute(cmd String, neoStores NeoStores) : boolean in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method private getStore(fname String, neoStores NeoStores) : RecordStore in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Rename Parameter transactionIdStore : TransactionIdStore to neoStores : NeoStores in method public StoreFlusher(neoStores NeoStores, indexingService IndexingService, labelScanStore LabelScanStore, indexProviders Iterable<IndexImplementation>) in class org.neo4j.kernel.impl.transaction.log.rotation.StoreFlusher |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public IndexUpdatesValidator(neoStores NeoStores, kernelHealth KernelHealth, propertyLoader PropertyLoader, indexing IndexingService) in class org.neo4j.kernel.impl.api.index.IndexUpdatesValidator |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method private interact(neoStores NeoStores) : void in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method protected initialiseStore(neoStores NeoStores) : LabelTokenStore in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest.LabelTokenStoreConsistentReadTest |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method private getLogCursor(fname String, neoStores NeoStores) : IOCursor<LogEntry> in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public HighIdTransactionApplier(delegate CommandHandler, neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.command.HighIdTransactionApplier |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method private alreadyContainsData(neoStores NeoStores) : boolean in class org.neo4j.unsafe.impl.batchimport.store.BatchingNeoStores |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public StoreNodeRelationshipCursor(relationshipRecord RelationshipRecord, neoStores NeoStores, groupRecord RelationshipGroupRecord, storeStatement StoreStatement, instanceCache Consumer<StoreNodeRelationshipCursor>) in class org.neo4j.kernel.impl.api.store.StoreNodeRelationshipCursor |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public StoreAbstractRelationshipCursor(relationshipRecord RelationshipRecord, neoStores NeoStores, storeStatement StoreStatement) in class org.neo4j.kernel.impl.api.store.StoreAbstractRelationshipCursor |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public StoreAbstractNodeCursor(nodeRecord NodeRecord, neoStores NeoStores, storeStatement StoreStatement) in class org.neo4j.kernel.impl.api.store.StoreAbstractNodeCursor |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public TransactionRepresentationStoreApplier(indexingService IndexingService, labelScanWriters Provider<LabelScanWriter>, neoStores NeoStores, cacheAccess CacheAccessBackDoor, lockService LockService, legacyIndexProviderLookup LegacyIndexApplierLookup, indexConfigStore IndexConfigStore, health KernelHealth, legacyIndexTransactionOrdering IdOrderingQueue) in class org.neo4j.kernel.impl.api.TransactionRepresentationStoreApplier |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method private buildStoreLayer(neoStores NeoStores, propertyKeyTokenHolder PropertyKeyTokenHolder, labelTokens LabelTokenHolder, relationshipTypeTokens RelationshipTypeTokenHolder, indexingService IndexingService, schemaCache SchemaCache, procedureCache ProcedureCache) : StoreLayerModule in class org.neo4j.kernel.NeoStoreDataSource |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public TransactionalWorker(neoStores NeoStores, appender TransactionAppender, storeApplier TransactionRepresentationStoreApplier, completedLatch CountDownLatch) in class org.neo4j.kernel.impl.api.TransactionRepresentationCommitProcessIT.TransactionalWorker |
From |
To |
|
Rename Parameter neoStore : NeoStore to metaDataStore : MetaDataStore in method private createCheckPointer(metaDataStore MetaDataStore, kernelHealth KernelHealth, appender TransactionAppender) : CheckPointerImpl in class org.neo4j.kernel.impl.api.TransactionRepresentationCommitProcessIT |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method private buildIndexing(config Config, scheduler JobScheduler, indexProvider SchemaIndexProvider, lockService LockService, tokenNameLookup TokenNameLookup, logProvider LogProvider, indexingServiceMonitor IndexingService.Monitor, neoStores NeoStores, updateableSchemaState UpdateableSchemaState) : IndexingModule in class org.neo4j.kernel.NeoStoreDataSource |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public Tracker(neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.state.RelationshipCreatorTest.Tracker |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public BatchRelationshipIterable(neoStores NeoStores, nodeId long) in class org.neo4j.unsafe.batchinsert.BatchRelationshipIterable |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method private buildTransactionLogs(storeDir File, config Config, logProvider LogProvider, scheduler JobScheduler, labelScanStore LabelScanStore, fileSystemAbstraction FileSystemAbstraction, neoStores NeoStores, cacheAccess CacheAccessBackDoor, indexingService IndexingService, indexProviders Iterable<IndexImplementation>) : TransactionLogModule in class org.neo4j.kernel.NeoStoreDataSource |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method private read(cmd String, neoStores NeoStores) : void in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Rename Parameter neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public fullStoreLabelUpdateStream(neoStoresSupplier NeoStoresSupplier) : FullStoreChangeStream in class org.neo4j.kernel.impl.api.scan.LabelScanStoreProvider |
From |
To |
|
Rename Parameter factory : StoreFactory to neoStores : NeoStores in method package DumpCountsStore(out PrintStream, neoStores NeoStores) in class org.neo4j.kernel.impl.store.counts.DumpCountsStore |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public StoreSingleNodeCursor(nodeRecord NodeRecord, neoStores NeoStores, storeStatement StoreStatement, instanceCache Consumer<StoreSingleNodeCursor>) in class org.neo4j.kernel.impl.api.store.StoreSingleNodeCursor |
From |
To |
|
Rename Parameter neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public PropertyCountSampleable(neoStoresSupplier NeoStoresSupplier) in class org.neo4j.server.rrd.sampler.PropertyCountSampleable |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method private listFiles(neoStores NeoStores) : void in class org.neo4j.kernel.impl.util.rawstorereader.RsdrMain |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public TransactionRecordState(neoStores NeoStores, integrityValidator IntegrityValidator, context NeoStoreTransactionContext) in class org.neo4j.kernel.impl.transaction.state.TransactionRecordState |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public PropertyLoader(neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.state.PropertyLoader |
From |
To |
|
Rename Parameter neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public DatabasePrimitivesSampleableBase(neoStoresSupplier NeoStoresSupplier) in class org.neo4j.server.rrd.sampler.DatabasePrimitivesSampleableBase |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method protected getStore(neoStores NeoStores) : SchemaStore in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest.SchemaStoreConsistentReadTest |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public StoreStatement(neoStores NeoStores) in class org.neo4j.kernel.impl.api.store.StoreStatement |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method protected getStore(neoStores NeoStores) : PropertyStore in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest.PropertyStoreConsistentReadTest |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public NeoStoreIndexStoreView(locks LockService, neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.state.NeoStoreIndexStoreView |
From |
To |
|
Rename Parameter neostore : NeoStore to neoStores : NeoStores in method package emulateFailureOnRebuildOf(neoStores NeoStores) : void in class org.neo4j.kernel.impl.store.IdGeneratorRebuildFailureEmulationTest |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method public RecordChangeSet(beforeStateForAll boolean, neoStores NeoStores) in class org.neo4j.kernel.impl.transaction.state.RecordChangeSet |
From |
To |
|
Rename Parameter neoStoreSupplier : NeoStoreSupplier to neoStoresSupplier : NeoStoresSupplier in method public NodeIdsInUseSampleable(neoStoresSupplier NeoStoresSupplier) in class org.neo4j.server.rrd.sampler.NodeIdsInUseSampleable |
From |
To |
|
Rename Parameter neoStore : NeoStore to neoStores : NeoStores in method protected getStore(neoStores NeoStores) : RelationshipStore in class org.neo4j.kernel.impl.store.RecordStoreConsistentReadTest.RelationshipStoreConsistentReadTest |
From |
To |