|
Change Parameter Type unit : TimeUnit to unit : ChronoUnit in method public abbreviate(unit ChronoUnit) : String in class com.thinkaurelius.titan.diskstorage.util.time.Durations |
From |
To |
|
Change Parameter Type tsNS : long to tsNS : Instant in method public LockInfo(tsNS Instant, stat ConsistentKeyLockStatus, col StaticBuffer) in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest.LockInfo |
From |
To |
|
Change Parameter Type commit : Timepoint to commit : Instant in method public commitTime(commit Instant) : Builder in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig.Builder |
From |
To |
|
Change Parameter Type time : Timepoint to time : Instant in method public setCommitTime(time Instant) : void in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder.ImmutableTxCfg |
From |
To |
|
Change Parameter Type timestamp : Timepoint to timestamp : Instant in method private getBlockApplication(blockValue long, timestamp Instant) : StaticBuffer in class com.thinkaurelius.titan.diskstorage.idmanagement.ConsistentKeyIDAuthority |
From |
To |
|
Change Parameter Type preferredTimestamps : Timestamps to preferredTimestamps : TimestampProviders in method private StandardStoreFeatures(unorderedScan boolean, orderedScan boolean, multiQuery boolean, locking boolean, batchMutation boolean, localKeyPartition boolean, keyOrdered boolean, distributed boolean, transactional boolean, keyConsistent boolean, timestamps boolean, preferredTimestamps TimestampProviders, cellLevelTTL boolean, storeLevelTTL boolean, visibility boolean, keyConsistentTxConfig Configuration, localKeyConsistentTxConfig Configuration, scanTxConfig Configuration) in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures |
From |
To |
|
Change Parameter Type expire : Timepoint to expire : Instant in method private lockLocally(lockID KeyColumn, expire Instant, tx StoreTransaction) : boolean in class com.thinkaurelius.titan.diskstorage.locking.AbstractLocker |
From |
To |
|
Change Parameter Type cutoff : long to cutoff : Instant in method public clean(target KeyColumn, cutoff Instant, tx StoreTransaction) : void in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.LockCleanerService |
From |
To |
|
Change Parameter Type unit : TimeUnit to unit : TemporalUnit in method public awaitGraphIndexUpdate(g TitanGraph, indexName String, time long, unit TemporalUnit) : void in class com.thinkaurelius.titan.core.util.ManagementUtil |
From |
To |
|
Change Parameter Type attribute : Timepoint to attribute : Instant in method public write(buffer WriteBuffer, attribute Instant) : void in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.InstantSerializer |
From |
To |
|
Change Parameter Type futureTime : Timepoint to futureTime : Instant in method public sleepPast(futureTime Instant) : Instant in class com.thinkaurelius.titan.diskstorage.util.time.TimestampProvider |
From |
To |
|
Change Parameter Type timestamp : Timepoint to timestamp : Instant in method private getTimeSlice(timestamp Instant) : int in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog |
From |
To |
|
Change Parameter Type time : Timepoint to time : Instant in method public setCommitTime(time Instant) : void in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder |
From |
To |
|
Change Parameter Type cutoff : long to cutoff : Instant in method public clean(target KeyColumn, cutoff Instant, tx StoreTransaction) : void in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerService |
From |
To |
|
Change Parameter Type expires : Timepoint to expires : Instant in method public lock(kc KeyColumn, requestor T, expires Instant) : boolean in class com.thinkaurelius.titan.diskstorage.locking.LocalLockMediator |
From |
To |
|
Change Parameter Type startTime : Timestamp to startTime : Instant in method public StandardTransactionLogProcessor(graph StandardTitanGraph, startTime Instant) in class com.thinkaurelius.titan.graphdb.log.StandardTransactionLogProcessor |
From |
To |
|
Change Parameter Type tu : TimeUnit to tu : TemporalUnit in method private recordSuccessfulLockDelete(duration long, tu TemporalUnit, del StaticBuffer) : void in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest |
From |
To |
|
Change Parameter Type expires : Timepoint to expires : Instant in method private AuditRecord(holder T, expires Instant, acquiredAt StackTraceElement[]) in class com.thinkaurelius.titan.diskstorage.locking.LocalLockMediator.AuditRecord |
From |
To |
|
Change Parameter Type commitTime : Timepoint to commitTime : Instant in method private overrideTimestamp(tx StoreTransaction, commitTime Instant) : StoreTransaction in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker |
From |
To |
|
Change Parameter Type commitTime : Timepoint to commitTime : Instant in method private StandardBaseTransactionConfig(groupName String, times TimestampProvider, commitTime Instant, customOptions Configuration) in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig |
From |
To |
|
Change Parameter Type transactionTime : Timestamp to transactionTime : Instant in method public StandardTransactionId(instanceId String, transactionId long, transactionTime Instant) in class com.thinkaurelius.titan.graphdb.log.StandardTransactionId |
From |
To |
|
Change Parameter Type tu : TimeUnit to tu : TemporalUnit in method private recordSuccessfulLockWrite(duration long, tu TemporalUnit, del StaticBuffer) : LockInfo in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest |
From |
To |
|
Change Parameter Type cutoff : long to cutoff : Instant in method public StandardLockCleanerRunnable(store KeyColumnValueStore, target KeyColumn, tx StoreTransaction, serializer ConsistentKeyLockerSerializer, cutoff Instant, times TimestampProvider) in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerRunnable |
From |
To |
|
Change Parameter Type time : Timepoint to time : Instant in method public setCommitTime(time Instant) : void in class com.thinkaurelius.titan.diskstorage.BaseTransactionConfig |
From |
To |
|
Change Parameter Type unit : TimeUnit to unit : TemporalUnit in method private awaitIndexUpdate(g TitanGraph, indexName String, relationTypeName String, time long, unit TemporalUnit) : void in class com.thinkaurelius.titan.core.util.ManagementUtil |
From |
To |
|
Change Parameter Type pollUnit : TimeUnit to pollUnit : TemporalUnit in method public pollInterval(poll long, pollUnit TemporalUnit) : S in class com.thinkaurelius.titan.graphdb.database.management.AbstractIndexStatusWatcher |
From |
To |
|
Change Parameter Type writeTimestamp : Timepoint to writeTimestamp : Instant in method public WriteResult(duration Duration, writeTimestamp Instant, lockCol StaticBuffer, throwable Throwable) in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker.WriteResult |
From |
To |
|
Change Parameter Type t : Timestamps to t : TimestampProviders in method public preferredTimestamps(t TimestampProviders) : Builder in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder |
From |
To |
|
Change Parameter Type written : Timepoint to written : Instant in method public ConsistentKeyLockStatus(written Instant, expire Instant) in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus |
From |
To |
|
Change Parameter Type timestamp : long to timestamp : Instant in method public fromIdentifierOrTime(id String, timestamp Instant) : ReadMarker in class com.thinkaurelius.titan.diskstorage.log.ReadMarker |
From |
To |
|
Change Parameter Type timestamp : Timepoint to timestamp : Instant in method public KCVSMessage(payload StaticBuffer, timestamp Instant, senderId String) in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSMessage |
From |
To |
|
Change Parameter Type ts : long to ts : Instant in method public toLockCol(ts Instant, rid StaticBuffer, provider TimestampProvider) : StaticBuffer in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockerSerializer |
From |
To |
|
Change Parameter Type attribute : StandardDuration to attribute : Duration in method public write(buffer WriteBuffer, attribute Duration) : void in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DurationSerializer |
From |
To |
|
Change Parameter Type unit : TimeUnit to times : TimestampProvider in method public getDeletionTime(times TimestampProvider) : long in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager.MaskedTimestamp |
From |
To |
|
Change Parameter Type timestamp : long to timestamp : Instant in method public fromTime(timestamp Instant) : ReadMarker in class com.thinkaurelius.titan.diskstorage.log.ReadMarker |
From |
To |
|
Change Parameter Type futureTime : Timepoint to futureTime : Instant in method public sleepPast(futureTime Instant) : Instant in class com.thinkaurelius.titan.diskstorage.util.time.TimestampProviders |
From |
To |
|
Change Parameter Type timestamp : long to timestamp : Instant in method public TimestampRid(timestamp Instant, rid StaticBuffer) in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.TimestampRid |
From |
To |
|
Change Parameter Type timestamp : Timepoint to timestamp : Instant in method protected AbstractMessage(content StaticBuffer, timestamp Instant, senderId String) in class com.thinkaurelius.titan.diskstorage.log.util.AbstractMessage |
From |
To |
|
Change Parameter Type commitTime : Timepoint to commitTime : Instant in method public ImmutableTxCfg(isReadOnly boolean, hasEnabledBatchLoading boolean, hasAssignIDsImmediately boolean, hasPreloadedData boolean, hasForceIndexUsage boolean, hasVerifyExternalVertexExistence boolean, hasVerifyInternalVertexExistence boolean, hasAcquireLocks boolean, hasVerifyUniqueness boolean, hasPropertyPrefetching boolean, isSingleThreaded boolean, isThreadBound boolean, times TimestampProvider, commitTime Instant, indexCacheWeight long, vertexCacheSize int, dirtyVertexSize int, logIdentifier String, restrictedPartitions int[], groupName String, defaultSchemaMaker DefaultSchemaMaker, customOptions Configuration) in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder.ImmutableTxCfg |
From |
To |
|
Change Parameter Type timeoutUnit : TimeUnit to timeoutUnit : TemporalUnit in method public timeout(timeout long, timeoutUnit TemporalUnit) : S in class com.thinkaurelius.titan.graphdb.database.management.AbstractIndexStatusWatcher |
From |
To |
|
Change Parameter Type expire : Timepoint to expire : Instant in method public ConsistentKeyLockStatus(written Instant, expire Instant) in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus |
From |
To |
|
Change Parameter Type txTimestamp : Timepoint to txTimestamp : Instant in method public TransactionLogHeader(transactionId long, txTimestamp Instant, times TimestampProvider) in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader |
From |
To |
|
Change Parameter Type commitTime : Timepoint to commitTime : Instant in method public MaskedTimestamp(commitTime Instant) in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager.MaskedTimestamp |
From |
To |
|
Change Parameter Type unit : TimeUnit to unit : TemporalUnit in method public awaitVertexIndexUpdate(g TitanGraph, indexName String, relationTypeName String, time long, unit TemporalUnit) : void in class com.thinkaurelius.titan.core.util.ManagementUtil |
From |
To |
|
Change Parameter Type ts : long to ts : Instant in method private recordSuccessfulLocalLock(ts Instant) : void in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest |
From |
To |
|
Change Parameter Type time : Timepoint to time : Instant in method public setCommitTime(time Instant) : void in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig |
From |
To |
|
Change Parameter Type tu : TimeUnit to tu : TemporalUnit in method private recordSuccessfulLockWrite(tx StoreTransaction, duration long, tu TemporalUnit, del StaticBuffer) : LockInfo in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest |
From |
To |
|
Change Parameter Type tu : TimeUnit to tu : TemporalUnit in method private recordExceptionLockWrite(duration long, tu TemporalUnit, del StaticBuffer, t Throwable) : StaticBuffer in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest |
From |
To |
|
Change Parameter Type ts : long to ts : Instant in method private recordSuccessfulLocalLock(tx StoreTransaction, ts Instant) : void in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest |
From |
To |
|
Change Parameter Type u : TimeUnit to u : ChronoUnit in method public getSchemaConvergenceTime(u ChronoUnit) : long in class com.thinkaurelius.titan.testutil.TestGraphConfigs |
From |
To |
|
Change Return Type Timepoint to Instant in method public getTimestamp() : Instant in class com.thinkaurelius.titan.diskstorage.log.util.AbstractMessage |
From |
To |
|
Change Return Type Timepoint to Instant in method public getTime() : Instant in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest.FakeTimestampProvider |
From |
To |
|
Change Return Type Timestamp to Instant in method public getTransactionTime() : Instant in class com.thinkaurelius.titan.core.log.TransactionId |
From |
To |
|
Change Return Type Timepoint to Instant in method public sleepPast(futureTime Instant) : Instant in class com.thinkaurelius.titan.diskstorage.util.time.TimestampProvider |
From |
To |
|
Change Return Type Timepoint to Instant in method public getCommitTime() : Instant in class com.thinkaurelius.titan.diskstorage.BaseTransactionConfig |
From |
To |
|
Change Return Type Timestamps to TimestampProviders in method public getPreferredTimestamps() : TimestampProviders in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures |
From |
To |
|
Change Return Type Timepoint to Instant in method public getCommitTime() : Instant in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder.ImmutableTxCfg |
From |
To |
|
Change Return Type StandardDuration to Duration in method public read(buffer ScanBuffer) : Duration in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DurationSerializer |
From |
To |
|
Change Return Type Timepoint to Instant in method public getStartTime() : Instant in class com.thinkaurelius.titan.diskstorage.util.time.Timer |
From |
To |
|
Change Return Type Timepoint to Instant in method public getWriteTimestamp() : Instant in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus |
From |
To |
|
Change Return Type TimeUnit to ChronoUnit in method public getUnit() : ChronoUnit in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest.FakeTimestampProvider |
From |
To |
|
Change Return Type StandardTimepoint to Instant in method public read(buffer ScanBuffer) : Instant in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.InstantSerializer |
From |
To |
|
Change Return Type Timepoint to Instant in method public getWriteTimestamp() : Instant in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker.WriteResult |
From |
To |
|
Change Return Type Timestamp to Instant in method public getTransactionTime() : Instant in class com.thinkaurelius.titan.graphdb.log.StandardTransactionId |
From |
To |
|
Change Return Type Timepoint to Instant in method public getTime() : Instant in class com.thinkaurelius.titan.diskstorage.util.time.TimestampProvider |
From |
To |
|
Change Return Type TimeUnit to ChronoUnit in method public getUnit() : ChronoUnit in class com.thinkaurelius.titan.diskstorage.util.time.TimestampProvider |
From |
To |
|
Change Return Type Timepoint to Instant in method public sleepPast(futureTime Instant) : Instant in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest.FakeTimestampProvider |
From |
To |
|
Change Return Type long to Instant in method public getTimestamp() : Instant in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.TimestampRid |
From |
To |
|
Change Return Type Timepoint to Instant in method public getCommitTime() : Instant in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder |
From |
To |
|
Change Return Type Timepoint to Instant in method public getStartTime(times TimestampProvider) : Instant in class com.thinkaurelius.titan.diskstorage.log.ReadMarker |
From |
To |
|
Change Return Type TimeUnit to TemporalUnit in method public parse(unitName String) : TemporalUnit in class com.thinkaurelius.titan.diskstorage.util.time.Durations |
From |
To |
|
Change Return Type Timepoint to Instant in method public getExpirationTimestamp() : Instant in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus |
From |
To |
|
Change Return Type Timepoint to Instant in method public sleepPast(futureTime Instant) : Instant in class com.thinkaurelius.titan.diskstorage.util.time.TimestampProviders |
From |
To |
|
Change Return Type Timestamps to TimestampProviders in method public getPreferredTimestamps() : TimestampProviders in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StoreFeatures |
From |
To |
|
Change Return Type Timepoint to Instant in method public getCommitTime() : Instant in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig |
From |
To |
|
Change Return Type Timepoint to Instant in method public getExpirationTimestamp() : Instant in class com.thinkaurelius.titan.diskstorage.locking.LockStatus |
From |
To |
|
Change Variable Type nowTimestamp : Timepoint to nowTimestamp : Instant in method private timeSinceFirstMsg() : Duration in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog.SendThread |
From |
To |
|
Change Variable Type expireInstant : Timepoint to expireInstant : Instant in method protected writeSingleLock(lockID KeyColumn, txh StoreTransaction) : ConsistentKeyLockStatus in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker |
From |
To |
|
Change Variable Type timesliceEnd : Timepoint to timesliceEnd : Instant in method public run() : void in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog.MessagePuller |
From |
To |
|
Change Variable Type msgTime : long to msgTime : Instant in method public read(message Message) : void in class com.thinkaurelius.titan.graphdb.TitanGraphTest.simpleLogTest.registerReader |
From |
To |
|
Change Variable Type utime : Timepoint to utime : Instant in method private testExpiration(expirationTime Duration) : void in class com.thinkaurelius.titan.diskstorage.cache.ExpirationCacheTest |
From |
To |
|
Change Variable Type txTimes : Timepoint[] to txTimes : Instant[] in method public simpleLogTest(withLogFailure boolean) : void in class com.thinkaurelius.titan.graphdb.TitanGraphTest |
From |
To |
|
Change Variable Type unit : TimeUnit to unit : TemporalUnit in method public parse(unitName String) : TemporalUnit in class com.thinkaurelius.titan.diskstorage.util.time.Durations |
From |
To |
|
Change Variable Type entry : Map.Entry<TimeUnit,String> to entry : Map.Entry<ChronoUnit,String> in method public testDateParsing() : void in class com.thinkaurelius.titan.diskstorage.configuration.CommonConfigTest |
From |
To |
|
Change Variable Type txTime : long to txTime : Instant in method public read(message Message) : void in class com.thinkaurelius.titan.graphdb.TitanGraphTest.simpleLogTest.registerReader |
From |
To |
|
Change Variable Type now : Timepoint to now : Instant in method public sleepPast(futureTime Instant) : Instant in class com.thinkaurelius.titan.diskstorage.util.time.TimestampProviders |
From |
To |
|
Change Variable Type stopTime : Timepoint to stopTime : Instant in method public elapsed() : Duration in class com.thinkaurelius.titan.diskstorage.util.time.Timer |
From |
To |
|
Change Variable Type registrationTime : Timepoint to registrationTime : Instant in method public forceCloseInstance(instanceId String) : void in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem |
From |
To |
|
Change Variable Type now : Timepoint to now : Instant in method protected checkSingleLock(kc KeyColumn, ls ConsistentKeyLockStatus, tx StoreTransaction) : void in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker |
From |
To |
|
Change Variable Type unit : TimeUnit to unit : ChronoUnit in method public sleepPast(futureTime Instant) : Instant in class com.thinkaurelius.titan.diskstorage.util.time.TimestampProviders |
From |
To |
|
Change Variable Type end : Timepoint to end : Instant in method private awaitIndexUpdate(g TitanGraph, indexName String, relationTypeName String, time long, unit TemporalUnit) : void in class com.thinkaurelius.titan.core.util.ManagementUtil |
From |
To |
|
Change Variable Type unit : TimeUnit to unit : TemporalUnit in method public get(key String, datatype Class<O>) : O in class com.thinkaurelius.titan.diskstorage.configuration.backend.CommonsConfiguration |
From |
To |
|
Change Variable Type startTime : long to startTime : Instant in method public testIndexReplay() : void in class com.thinkaurelius.titan.graphdb.TitanIndexTest |
From |
To |
|
Change Variable Type t : Timestamp to t : Instant in method public testTimestampSetting() : void in class com.thinkaurelius.titan.graphdb.TitanEventualGraphTest |
From |
To |
|
Change Variable Type writeInstant : Timepoint to writeInstant : Instant in method protected writeSingleLock(lockID KeyColumn, txh StoreTransaction) : ConsistentKeyLockStatus in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker |
From |
To |
|
Change Variable Type maxSafeMessageTime : Timepoint to maxSafeMessageTime : Instant in method public run() : void in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog.MessagePuller |
From |
To |
|
Change Variable Type firstTimestamp : Timepoint to firstTimestamp : Instant in method private timeSinceFirstMsg() : Duration in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog.SendThread |
From |
To |
|
Change Variable Type lockNS : long to lockNS : Instant in method private recordSuccessfulLockWrite(tx StoreTransaction, duration long, tu TemporalUnit, del StaticBuffer) : LockInfo in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest |
From |
To |
|
Change Variable Type b : Long to b : Instant in method public clean(target KeyColumn, cutoff Instant, tx StoreTransaction) : void in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerService |
From |
To |
|
Change Variable Type messageTimeEnd : Timepoint to messageTimeEnd : Instant in method public run() : void in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog.MessagePuller |
From |
To |
|
Change Variable Type backendPreference : Timestamps to backendPreference : TimestampProviders in method public GraphDatabaseConfiguration(localConfig ReadConfiguration) in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Variable Type txTimestamp : Timepoint to txTimestamp : Instant in method public parse(buffer StaticBuffer, serializer Serializer, times TimestampProvider) : Entry in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader |
From |
To |
|
Change Variable Type unit : TimeUnit to unit : TemporalUnit in method public get(key String, datatype Class<O>) : O in class com.thinkaurelius.titan.hadoop.config.HadoopConfiguration |
From |
To |
|
Change Variable Type txTimestamp : Timepoint to txTimestamp : Instant in method public commit(addedRelations Collection<InternalRelation>, deletedRelations Collection<InternalRelation>, tx StandardTitanTx) : void in class com.thinkaurelius.titan.graphdb.database.StandardTitanGraph |
From |
To |
|
Change Variable Type timestamp : Timepoint to timestamp : Instant in method private parseMessage(msg Entry) : KCVSMessage in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog |
From |
To |
|
Change Variable Type rawTimestamp : long to rawTimestamp : Instant in method private writeMessage(msg KCVSMessage) : Entry in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog |
From |
To |
|
Change Variable Type unit : TimeUnit to unit : ChronoUnit in method public testDateParsing() : void in class com.thinkaurelius.titan.diskstorage.configuration.CommonConfigTest |
From |
To |
|
Change Variable Type currentTime : Timepoint to currentTime : Instant in method public run() : void in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog.MessagePuller |
From |
To |
|
Change Variable Type timestamp : Timepoint to timestamp : Instant in method private add(content StaticBuffer, partitionId int, persistor ExternalPersistor) : Future<Message> in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog |
From |
To |
|
Change Variable Type utime : Timepoint to utime : Instant in method private testGracePeriod(graceWait Duration) : void in class com.thinkaurelius.titan.diskstorage.cache.ExpirationCacheTest |
From |
To |
|
Change Variable Type u : TimeUnit to u : TemporalUnit in method public toString() : String in class com.thinkaurelius.titan.diskstorage.util.time.Timer |
From |
To |
|
Change Attribute Type defaultWaitNS : long to defaultWaitNS : Duration in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest |
From |
To |
|
Change Attribute Type tsNS : long to tsNS : Instant in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest.LockInfo |
From |
To |
|
Change Attribute Type userCommitTime : Timepoint to userCommitTime : Instant in class com.thinkaurelius.titan.graphdb.transaction.StandardTransactionBuilder |
From |
To |
|
Change Attribute Type t : Timepoint to t : Instant in class com.thinkaurelius.titan.diskstorage.common.DistributedStoreManager.MaskedTimestamp |
From |
To |
|
Change Attribute Type messageTimeStart : Timepoint to messageTimeStart : Instant in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog.MessagePuller |
From |
To |
|
Change Attribute Type METRICS_CSV_INTERVAL : ConfigOption<StandardDuration> to METRICS_CSV_INTERVAL : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type LOG_MAX_READ_TIME : ConfigOption<StandardDuration> to LOG_MAX_READ_TIME : ConfigOption<Duration> in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog |
From |
To |
|
Change Attribute Type timestamp : long to timestamp : Instant in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.TimestampRid |
From |
To |
|
Change Attribute Type units : EnumSerializer<TimeUnit> to nanosSerializer : IntegerSerializer in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.DurationSerializer |
From |
To |
|
Change Attribute Type startTime : Timestamp to startTime : Instant in class com.thinkaurelius.titan.graphdb.log.StandardLogProcessorFramework.Builder |
From |
To |
|
Change Attribute Type lastInvocation : Timepoint to lastInvocation : Instant in class com.thinkaurelius.titan.graphdb.log.StandardTransactionLogProcessor.BackgroundCleaner |
From |
To |
|
Change Attribute Type preferredTimestamps : Timestamps to preferredTimestamps : TimestampProviders in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures |
From |
To |
|
Change Attribute Type LOCK_EXPIRE : ConfigOption<StandardDuration> to LOCK_EXPIRE : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type cutoff : long to cutoff : Instant in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerRunnable |
From |
To |
|
Change Attribute Type blocked : ConcurrentMap<KeyColumn,Long> to blocked : ConcurrentMap<KeyColumn,Instant> in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerService |
From |
To |
|
Change Attribute Type COOLDOWN_TIME : long to COOLDOWN_TIME : Duration in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.StandardLockCleanerService |
From |
To |
|
Change Attribute Type METRICS_SLF4J_INTERVAL : ConfigOption<StandardDuration> to METRICS_SLF4J_INTERVAL : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type METRICS_CONSOLE_INTERVAL : ConfigOption<StandardDuration> to METRICS_CONSOLE_INTERVAL : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type LOCK_WAIT : ConfigOption<StandardDuration> to LOCK_WAIT : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type LOG_READ_LAG_TIME : ConfigOption<StandardDuration> to LOG_READ_LAG_TIME : ConfigOption<Duration> in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog |
From |
To |
|
Change Attribute Type writeTimestamp : Timepoint to writeTimestamp : Instant in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLocker.WriteResult |
From |
To |
|
Change Attribute Type GANGLIA_INTERVAL : ConfigOption<StandardDuration> to GANGLIA_INTERVAL : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type startTime : Timepoint to startTime : Instant in class com.thinkaurelius.titan.diskstorage.log.ReadMarker |
From |
To |
|
Change Attribute Type unitNames : Map<String,TimeUnit> to unitNames : Map<String,TemporalUnit> in class com.thinkaurelius.titan.diskstorage.util.time.Durations |
From |
To |
|
Change Attribute Type LOG_STORE_TTL : ConfigOption<StandardDuration> to LOG_STORE_TTL : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type LOG_MAX_WRITE_TIME : ConfigOption<StandardDuration> to LOG_MAX_WRITE_TIME : ConfigOption<Duration> in class com.thinkaurelius.titan.diskstorage.log.kcvs.KCVSLog |
From |
To |
|
Change Attribute Type GRAPHITE_INTERVAL : ConfigOption<StandardDuration> to GRAPHITE_INTERVAL : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type TIMESTAMP_PROVIDER : ConfigOption<Timestamps> to TIMESTAMP_PROVIDER : ConfigOption<TimestampProviders> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type currentTimeNS : long to currentTimeNS : Instant in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest |
From |
To |
|
Change Attribute Type IDAUTHORITY_WAIT : ConfigOption<StandardDuration> to IDAUTHORITY_WAIT : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type expires : Timepoint to expires : Instant in class com.thinkaurelius.titan.diskstorage.locking.LocalLockMediator.AuditRecord |
From |
To |
|
Change Attribute Type write : Timepoint to write : Instant in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus |
From |
To |
|
Change Attribute Type timestamp : Timepoint to timestamp : Instant in class com.thinkaurelius.titan.diskstorage.log.util.AbstractMessage |
From |
To |
|
Change Attribute Type timestamp : EnumSerializer<Timestamps> to nanosSerializer : IntegerSerializer in class com.thinkaurelius.titan.graphdb.database.serialize.attribute.InstantSerializer |
From |
To |
|
Change Attribute Type expire : Timepoint to expire : Instant in class com.thinkaurelius.titan.diskstorage.locking.consistentkey.ConsistentKeyLockStatus |
From |
To |
|
Change Attribute Type PREFERRED_TIMESTAMPS : Timestamps to PREFERRED_TIMESTAMPS : TimestampProviders in class com.thinkaurelius.titan.diskstorage.hbase.HBaseStoreManager |
From |
To |
|
Change Attribute Type start : Timepoint to start : Instant in class com.thinkaurelius.titan.diskstorage.util.time.Timer |
From |
To |
|
Change Attribute Type transactionTime : Timestamp to transactionTime : Instant in class com.thinkaurelius.titan.graphdb.log.StandardTransactionId |
From |
To |
|
Change Attribute Type MAX_COMMIT_TIME : ConfigOption<StandardDuration> to MAX_COMMIT_TIME : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type STORAGE_WRITE_WAITTIME : ConfigOption<StandardDuration> to STORAGE_WRITE_WAITTIME : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type commitTime : Timepoint to commitTime : Instant in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig |
From |
To |
|
Change Attribute Type time : Timepoint to time : Instant in class com.thinkaurelius.titan.graphdb.TestMockLog.TestMessage |
From |
To |
|
Change Attribute Type REGISTRATION_TIME : ConfigOption<Timepoint> to REGISTRATION_TIME : ConfigOption<Instant> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type jobStartTimeMS : long to jobStartTime : Instant in class com.thinkaurelius.titan.graphdb.olap.job.IndexUpdateJob |
From |
To |
|
Change Attribute Type txStartTime : Timepoint to txStartTime : Instant in class com.thinkaurelius.titan.graphdb.database.management.ManagementSystem |
From |
To |
|
Change Attribute Type CONNECTION_TIMEOUT : ConfigOption<StandardDuration> to CONNECTION_TIMEOUT : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type LOG_READ_INTERVAL : ConfigOption<StandardDuration> to LOG_READ_INTERVAL : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type IDS_RENEW_TIMEOUT : ConfigOption<StandardDuration> to IDS_RENEW_TIMEOUT : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type STORAGE_READ_WAITTIME : ConfigOption<StandardDuration> to STORAGE_READ_WAITTIME : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type jobStartTimeMS : long to jobStartTime : Instant in class com.thinkaurelius.titan.graphdb.olap.job.GhostVertexRemover |
From |
To |
|
Change Attribute Type stop : Timepoint to stop : Instant in class com.thinkaurelius.titan.diskstorage.util.time.Timer |
From |
To |
|
Change Attribute Type TRANSACTION_LOG_DEFAULT_TTL : StandardDuration to TRANSACTION_LOG_DEFAULT_TTL : Duration in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type commitTime : Timepoint to commitTime : Instant in class com.thinkaurelius.titan.diskstorage.util.StandardBaseTransactionConfig.Builder |
From |
To |
|
Change Attribute Type txTimestamp : Timepoint to txTimestamp : Instant in class com.thinkaurelius.titan.graphdb.database.log.TransactionLogHeader |
From |
To |
|
Change Attribute Type defaultExpireNS : long to defaultExpireNS : Duration in class com.thinkaurelius.titan.diskstorage.locking.ConsistentKeyLockerTest |
From |
To |
|
Change Attribute Type SETUP_WAITTIME : ConfigOption<StandardDuration> to SETUP_WAITTIME : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |
|
Change Attribute Type preferredTimestamps : Timestamps to preferredTimestamps : TimestampProviders in class com.thinkaurelius.titan.diskstorage.keycolumnvalue.StandardStoreFeatures.Builder |
From |
To |
|
Change Attribute Type LOG_SEND_DELAY : ConfigOption<StandardDuration> to LOG_SEND_DELAY : ConfigOption<Duration> in class com.thinkaurelius.titan.graphdb.configuration.GraphDatabaseConfiguration |
From |
To |