|
Change Parameter Type theEntries : Entry<?,?>[] to immutableEntries : Entry<?,?>... in method package RegularImmutableMap(immutableEntries Entry<?,?>...) in class com.google.common.collect.RegularImmutableMap |
From |
To |
|
Change Parameter Type multimap : ImmutableMultimap<K,V> to multimap : ImmutableMultimap<?,V> in method package Values(multimap ImmutableMultimap<?,V>) in class com.google.common.collect.ImmutableMultimap.Values |
From |
To |
|
Change Parameter Type subscriber : EventSubscriber to handler : EventHandler in method package enqueueEvent(event Object, handler EventHandler) : void in class com.google.common.eventbus.AsyncEventBus |
From |
To |
|
Change Parameter Type function : Function<? super T,V> to function : Function<Object,V> in method public transform(function Function<Object,V>) : Optional<V> in class com.google.common.base.Absent |
From |
To |
|
Change Parameter Type mapper : Function<? super Exception,X> to mapper : Function<Exception,X> in method public makeChecked(future ListenableFuture<V>, mapper Function<Exception,X>) : CheckedFuture<V,X> in class com.google.common.util.concurrent.Futures |
From |
To |
|
Change Parameter Type readers : Iterator<? extends CharSource> to readers : Iterator<? extends InputSupplier<? extends Reader>> in method package MultiReader(readers Iterator<? extends InputSupplier<? extends Reader>>) in class com.google.common.io.MultiReader |
From |
To |
|
Change Parameter Type subscriber : EventSubscriber to handler : EventHandler in method package enqueueEvent(event Object, handler EventHandler) : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Change Parameter Type defaultValue : T to defaultValue : Object in method public or(defaultValue Object) : Object in class com.google.common.base.Absent |
From |
To |
|
Change Parameter Type toElement : K to toElement : R in method public subSet(fromElement R, toElement R) : SortedSet<R> in class com.google.common.collect.StandardRowSortedTable.RowKeySortedSet |
From |
To |
|
Change Parameter Type inputStream : InputStream to closeable : Closeable in method public closeQuietly(closeable Closeable) : void in class com.google.common.io.Closeables |
From |
To |
|
Change Parameter Type entry : Entry<? extends K,? extends V> to entry : Entry<K,V> in method package SingletonImmutableBiMap(entry Entry<K,V>) in class com.google.common.collect.SingletonImmutableBiMap |
From |
To |
|
Change Parameter Type charset : Charset to elements : Object[] in method package SerializedForm(elements Object[]) in class com.google.common.collect.ImmutableCollection.SerializedForm |
From |
To |
|
Change Parameter Type it : Iterator<? extends ByteSource> to it : Iterator<? extends InputSupplier<? extends InputStream>> in method public MultiInputStream(it Iterator<? extends InputSupplier<? extends InputStream>>) in class com.google.common.io.MultiInputStream |
From |
To |
|
Change Parameter Type funnel : Funnel<? super T> to funnel : Funnel<T> in method public create(funnel Funnel<T>, expectedInsertions int) : BloomFilter<T> in class com.google.common.hash.BloomFilter |
From |
To |
|
Change Parameter Type index : long to index : int in method package set(index int) : boolean in class com.google.common.hash.BloomFilterStrategies.BitArray |
From |
To |
|
Change Parameter Type mapper : Function<? super Exception,X> to mapper : Function<Exception,X> in method package MappingCheckedFuture(delegate ListenableFuture<V>, mapper Function<Exception,X>) in class com.google.common.util.concurrent.Futures.MappingCheckedFuture |
From |
To |
|
Change Parameter Type stopwatch : SleepingStopwatch to ticker : SleepingTicker in method package WarmingUp(ticker SleepingTicker, warmupPeriod long, timeUnit TimeUnit) in class com.google.common.util.concurrent.RateLimiter.WarmingUp |
From |
To |
|
Change Parameter Type map : Map<K,? extends V> to map : Map<K,V> in method public immutableEnumMap(map Map<K,V>) : ImmutableMap<K,V> in class com.google.common.collect.Maps |
From |
To |
|
Change Parameter Type fromElement : K to fromElement : R in method public subSet(fromElement R, toElement R) : SortedSet<R> in class com.google.common.collect.StandardRowSortedTable.RowKeySortedSet |
From |
To |
|
Change Parameter Type subscriber : EventSubscriber to handler : EventHandler in method package dispatch(event Object, handler EventHandler) : void in class com.google.common.eventbus.AsyncEventBus |
From |
To |
|
Change Parameter Type entryPredicate : Predicate<? super Entry<K,V>> to entryPredicate : Predicate<Entry<K,V>> in method package FilteredKeyMap(unfiltered Map<K,V>, keyPredicate Predicate<? super K>, entryPredicate Predicate<Entry<K,V>>) in class com.google.common.collect.Maps.FilteredKeyMap |
From |
To |
|
Change Parameter Type e : Entry<K,V> to e : Node<K,V> in method public add(e Node<K,V>) : void in class com.google.common.collect.LinkedListMultimap.NodeIterator |
From |
To |
|
Change Parameter Type stopwatch : SleepingStopwatch to ticker : SleepingTicker in method package create(ticker SleepingTicker, permitsPerSecond double) : RateLimiter in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Change Parameter Type state : WeakReference<ServiceManagerState> to state : ServiceManagerState in method package ServiceListener(service Service, state ServiceManagerState) in class com.google.common.util.concurrent.ServiceManager.ServiceListener |
From |
To |
|
Change Parameter Type fromElement : K to fromElement : R in method public tailSet(fromElement R) : SortedSet<R> in class com.google.common.collect.StandardRowSortedTable.RowKeySortedSet |
From |
To |
|
Change Parameter Type hc : int[] to hc : HashCode in method package retryUpdate(x long, hc HashCode, wasUncontended boolean) : void in class com.google.common.cache.Striped64 |
From |
To |
|
Change Parameter Type typeTable : TypeTable to typeTable : ImmutableMap<TypeVariable<?>,Type> in method private TypeResolver(typeTable ImmutableMap<TypeVariable<?>,Type>) in class com.google.common.reflect.TypeResolver |
From |
To |
|
Change Parameter Type multiset : SortedMultiset<E> to multiset : SortedMultiset<?> in method package SerializedForm(multiset SortedMultiset<?>) in class com.google.common.collect.ImmutableSortedMultiset.SerializedForm |
From |
To |
|
Change Parameter Type mapMaker : MapMaker to mapMaker : GenericMapMaker<? super E,? super Number> in method public create(mapMaker GenericMapMaker<? super E,? super Number>) : ConcurrentHashMultiset<E> in class com.google.common.collect.ConcurrentHashMultiset |
From |
To |
|
Change Parameter Type nextInKeyBucket : ImmutableMapEntry<K,V> to nextInKToVBucket : BiMapEntry<K,V> in method package NonTerminalBiMapEntry(key K, value V, nextInKToVBucket BiMapEntry<K,V>, nextInVToKBucket BiMapEntry<K,V>) in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry |
From |
To |
|
Change Parameter Type var : TypeVariableKey to var : TypeVariable<?> in method private map(var TypeVariable<?>, arg Type) : void in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector |
From |
To |
|
Change Parameter Type e : Entry<K,V> to e : Node<K,V> in method public set(e Node<K,V>) : void in class com.google.common.collect.LinkedListMultimap.NodeIterator |
From |
To |
|
Change Parameter Type byteArrayInputStream : ByteArrayInputStream to bytes : byte[] in method package ByteArrayDataInputStream(bytes byte[]) in class com.google.common.io.ByteStreams.ByteArrayDataInputStream |
From |
To |
|
Change Parameter Type subscriber : EventSubscriber to handler : EventHandler in method public EventWithHandler(event Object, handler EventHandler) in class com.google.common.eventbus.EventBus.EventWithHandler |
From |
To |
|
Change Parameter Type stopwatch : SleepingStopwatch to ticker : SleepingTicker in method private RateLimiter(ticker SleepingTicker) in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Change Parameter Type funnel : Funnel<? super T> to funnel : Funnel<T> in method public create(funnel Funnel<T>, expectedInsertions int, fpp double) : BloomFilter<T> in class com.google.common.hash.BloomFilter |
From |
To |
|
Change Parameter Type toElement : K to toElement : R in method public headSet(toElement R) : SortedSet<R> in class com.google.common.collect.StandardRowSortedTable.RowKeySortedSet |
From |
To |
|
Change Parameter Type entriesToAdd : Entry<?,?>[] to entriesToAdd : Collection<? extends Entry<? extends K,? extends V>> in method package RegularImmutableBiMap(entriesToAdd Collection<? extends Entry<? extends K,? extends V>>) in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Change Parameter Type nextInValueBucket : ImmutableMapEntry<K,V> to nextInVToKBucket : BiMapEntry<K,V> in method package NonTerminalBiMapEntry(key K, value V, nextInKToVBucket BiMapEntry<K,V>, nextInVToKBucket BiMapEntry<K,V>) in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry |
From |
To |
|
Change Parameter Type readable : Readable to readable : R in method package asReader(readable R) : Reader in class com.google.common.io.CharStreams |
From |
To |
|
Change Parameter Type funnel : Funnel<? super T> to funnel : Funnel<T> in method private BloomFilter(bits BitArray, numHashFunctions int, funnel Funnel<T>, strategy Strategy) in class com.google.common.hash.BloomFilter |
From |
To |
|
Change Parameter Type entries : Entry<K,V>[] to entries : Collection<? extends Entry<? extends K,? extends V>> in method package fromSortedEntries(comparator Comparator<? super K>, entries Collection<? extends Entry<? extends K,? extends V>>) : ImmutableSortedMap<K,V> in class com.google.common.collect.ImmutableSortedMap |
From |
To |
|
Change Parameter Type entry : Entry<? extends K,? extends V> to entry : Entry<K,V> in method package unmodifiableEntry(entry Entry<K,V>) : Entry<K,V> in class com.google.common.collect.Maps |
From |
To |
|
Change Parameter Type multimap : FilteredMultimap<K,V> to multimap : Multimap<K,V> in method package Values(multimap Multimap<K,V>) in class com.google.common.collect.Multimaps.Values |
From |
To |
|
Change Parameter Type stopwatch : SleepingStopwatch to ticker : SleepingTicker in method package create(ticker SleepingTicker, permitsPerSecond double, warmupPeriod long, timeUnit TimeUnit) : RateLimiter in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Move Attribute package size : int from class com.google.common.util.concurrent.Striped.LargeLazyStriped to private size : int from class com.google.common.collect.ImmutableList.Builder |
From |
To |
|
Move Attribute package GOOD_FAST_HASH_FUNCTION_32 : HashFunction from class com.google.common.hash.Hashing.Murmur3_32Holder to private GOOD_FAST_HASH_FUNCTION_32 : HashFunction from class com.google.common.hash.Hashing |
From |
To |
|
Move Attribute private values : Collection<V> from class com.google.common.collect.AbstractTable to package values : Collection<V> from class com.google.common.collect.Maps.AbstractFilteredMap |
From |
To |
|
Move Attribute package MURMUR3_32 : HashFunction from class com.google.common.hash.Hashing.Murmur3_32Holder to private MURMUR3_32 : HashFunction from class com.google.common.hash.Hashing |
From |
To |
|
Move Attribute package CRC_32 : HashFunction from class com.google.common.hash.Hashing.Crc32Holder to private CRC_32 : HashFunction from class com.google.common.hash.Hashing |
From |
To |
|
Move Attribute package GOOD_FAST_HASH_FUNCTION_128 : HashFunction from class com.google.common.hash.Hashing.Murmur3_128Holder to private GOOD_FAST_HASH_FUNCTION_128 : HashFunction from class com.google.common.hash.Hashing |
From |
To |
|
Move Attribute package size : int from class com.google.common.util.concurrent.Striped.LargeLazyStriped to private size : int from class com.google.common.collect.ImmutableList.ReverseImmutableList |
From |
To |
|
Move Attribute package MURMUR3_128 : HashFunction from class com.google.common.hash.Hashing.Murmur3_128Holder to private MURMUR3_128 : HashFunction from class com.google.common.hash.Hashing |
From |
To |
|
Move Attribute package ADLER_32 : HashFunction from class com.google.common.hash.Hashing.Adler32Holder to private ADLER_32 : HashFunction from class com.google.common.hash.Hashing |
From |
To |
|
Move Attribute private values : Collection<V> from class com.google.common.collect.AbstractTable to private values : Collection<V> from class com.google.common.collect.ArrayTable |
From |
To |
|
Move Attribute package unfiltered : Multimap<K,V> from class com.google.common.collect.FilteredEntryMultimap to package unfiltered : Multimap<K,V> from class com.google.common.collect.FilteredMultimap |
From |
To |
|
Move Attribute package unfiltered : Multimap<K,V> from class com.google.common.collect.FilteredKeyMultimap to package unfiltered : Multimap<K,V> from class com.google.common.collect.FilteredMultimap |
From |
To |
|
Move Attribute package SHA_512 : HashFunction from class com.google.common.hash.Hashing.Sha512Holder to private SHA_512 : HashFunction from class com.google.common.hash.Hashing |
From |
To |
|
Move Attribute package rng : Random from class com.google.common.cache.Striped64 to package rng : Random from class com.google.common.cache.Striped64.HashCode |
From |
To |
|
Move Attribute package SHA_1 : HashFunction from class com.google.common.hash.Hashing.Sha1Holder to private SHA_1 : HashFunction from class com.google.common.hash.Hashing |
From |
To |
|
Move Attribute package MD5 : HashFunction from class com.google.common.hash.Hashing.Md5Holder to private MD5 : HashFunction from class com.google.common.hash.Hashing |
From |
To |
|
Move Attribute package SHA_256 : HashFunction from class com.google.common.hash.Hashing.Sha256Holder to private SHA_256 : HashFunction from class com.google.common.hash.Hashing |
From |
To |
|
Move Attribute private logger : Logger from class com.google.common.eventbus.EventBus.LoggingSubscriberExceptionHandler to private logger : Logger from class com.google.common.eventbus.EventBus |
From |
To |
|
Rename Method package abstract createCellSet() : ImmutableSet<Cell<R,C,V>> renamed to public abstract cellSet() : ImmutableSet<Cell<R,C,V>> in class com.google.common.collect.ImmutableTable |
From |
To |
|
Rename Method public hashUnencodedChars(input CharSequence) : HashCode renamed to public hashString(input CharSequence) : HashCode in class com.google.common.hash.Murmur3_32HashFunction |
From |
To |
|
Rename Method package removeFromColumnIf(predicate Predicate<? super Entry<R,V>>) : boolean renamed to package removePredicate(predicate Predicate<? super Entry<R,V>>) : boolean in class com.google.common.collect.StandardTable.Column |
From |
To |
|
Rename Method private awaitUninterruptibly(guard Guard, signalBeforeWaiting boolean) : void renamed to private waitUninterruptibly(guard Guard, signalBeforeWaiting boolean) : void in class com.google.common.util.concurrent.Monitor |
From |
To |
|
Rename Method private openInputStream() : InputStream renamed to private openStream() : InputStream in class com.google.common.io.FileBackedOutputStream |
From |
To |
|
Rename Method package KeySet() renamed to package map() : Map<K,V> in class com.google.common.collect.HashBiMap.KeySet |
From |
To |
|
Rename Method package createValues() : Collection<V> renamed to public values() : Collection<V> in class com.google.common.collect.Maps.AsMapView |
From |
To |
|
Rename Method package InverseKeySet() renamed to package map() : Map<V,K> in class com.google.common.collect.HashBiMap.Inverse.InverseKeySet |
From |
To |
|
Rename Method public findAllSubscribers(listener Object) : Multimap<Class<?>,EventSubscriber> renamed to public findAllHandlers(listener Object) : Multimap<Class<?>,EventHandler> in class com.google.common.eventbus.AnnotatedHandlerFinder |
From |
To |
|
Rename Method package createCellSet() : ImmutableSet<Cell<R,C,V>> renamed to public cellSet() : ImmutableSet<Cell<R,C,V>> in class com.google.common.collect.SingletonImmutableTable |
From |
To |
|
Rename Method public stopAsync() : Service renamed to public stopAndWait() : State in class com.google.common.util.concurrent.AbstractScheduledService |
From |
To |
|
Rename Method private makeSubscriber(listener Object, method Method) : EventSubscriber renamed to private makeHandler(listener Object, method Method) : EventHandler in class com.google.common.eventbus.AnnotatedHandlerFinder |
From |
To |
|
Rename Method public createKeySet() : Set<K> renamed to public keySet() : Set<K> in class com.google.common.collect.Maps.AsMapView |
From |
To |
|
Rename Method public startAsync() : Service renamed to public stop() : ListenableFuture<State> in class com.google.common.util.concurrent.AbstractExecutionThreadService |
From |
To |
|
Rename Method package getNextInKeyBucket() : ImmutableMapEntry<K,V> renamed to package getNextInVToKBucket() : BiMapEntry<K,V> in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry |
From |
To |
|
Rename Method public hashUnencodedChars(input CharSequence) : HashCode renamed to public hashString(input CharSequence) : HashCode in class com.google.common.hash.HashFunction |
From |
To |
|
Rename Method public putUnencodedChars(charSequence CharSequence) : Hasher renamed to public putString(charSequence CharSequence) : Hasher in class com.google.common.hash.AbstractStreamingHashFunction.AbstractStreamingHasher |
From |
To |
|
Rename Method public hashUnencodedChars(input CharSequence) : HashCode renamed to public hashString(input CharSequence) : HashCode in class com.google.common.hash.AbstractStreamingHashFunction |
From |
To |
|
Rename Method package visitParameterizedType(parameterizedType ParameterizedType) : void renamed to private introspectParameterizedType(parameterizedType ParameterizedType) : void in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector |
From |
To |
|
Rename Method package createValues() : ImmutableCollection<V> renamed to public values() : ImmutableCollection<V> in class com.google.common.collect.SingletonImmutableTable |
From |
To |
|
Rename Method public putUnencodedChars(charSequence CharSequence) : Hasher renamed to public putString(charSequence CharSequence) : Hasher in class com.google.common.hash.AbstractHasher |
From |
To |
|
Rename Method public startAsync() : Service renamed to public stop() : ListenableFuture<State> in class com.google.common.util.concurrent.Service |
From |
To |
|
Rename Method package bitSize() : long renamed to package size() : int in class com.google.common.hash.BloomFilterStrategies.BitArray |
From |
To |
|
Rename Method public hashUnencodedChars(input CharSequence) : HashCode renamed to public hashString(input CharSequence) : HashCode in class com.google.common.hash.AbstractNonStreamingHashFunction |
From |
To |
|
Rename Method package createEntrySet() : Set<Entry<K,Collection<V>>> renamed to public entrySet() : Set<Entry<K,Collection<V>>> in class com.google.common.collect.FilteredEntryMultimap.AsMap |
From |
To |
|
Rename Method public next() : T renamed to protected computeNext() : T in class com.google.common.collect.Iterators.MergingIterator |
From |
To |
|
Rename Method public stopAsync() : Service renamed to public stopAndWait() : State in class com.google.common.util.concurrent.AbstractExecutionThreadService |
From |
To |
|
Rename Method private splittingIterator(sequence CharSequence) : Iterator<String> renamed to private spliterator(sequence CharSequence) : Iterator<String> in class com.google.common.base.Splitter |
From |
To |
|
Rename Method public startAsync() : Service renamed to public stop() : ListenableFuture<State> in class com.google.common.util.concurrent.AbstractIdleService |
From |
To |
|
Rename Method package abstract getEntry(index int) : Entry<E> renamed to package abstract createEntrySet() : ImmutableSet<Entry<E>> in class com.google.common.collect.ImmutableMultiset |
From |
To |
|
Rename Method package getEntry(index int) : Entry<E> renamed to package createEntrySet() : ImmutableSet<Entry<E>> in class com.google.common.collect.EmptyImmutableSortedMultiset |
From |
To |
|
Rename Method package removeEntriesIf(predicate Predicate<? super Entry<K,Collection<V>>>) : boolean renamed to package removeIf(predicate Predicate<? super Entry<K,Collection<V>>>) : boolean in class com.google.common.collect.FilteredEntryMultimap |
From |
To |
|
Rename Method public stopAsync() : Service renamed to public stopAndWait() : State in class com.google.common.util.concurrent.Service |
From |
To |
|
Rename Method public startAsync() : Service renamed to public start() : ListenableFuture<State> in class com.google.common.util.concurrent.Service |
From |
To |
|
Rename Method private removeEntryIf(predicate Predicate<? super Entry<Range<K>,V>>) : boolean renamed to private removeIf(predicate Predicate<? super Entry<Range<K>,V>>) : boolean in class com.google.common.collect.TreeRangeMap.SubRangeMap.SubRangeMapAsMap |
From |
To |
|
Rename Method public unencodedCharsFunnel() : Funnel<CharSequence> renamed to public stringFunnel() : Funnel<CharSequence> in class com.google.common.hash.Funnels |
From |
To |
|
Rename Method public putUnencodedChars(charSequence CharSequence) : Hasher renamed to public putString(charSequence CharSequence) : Hasher in class com.google.common.hash.Hasher |
From |
To |
|
Rename Method package asMapEntryIterator(set Set<K>, function Function<? super K,V>) : Iterator<Entry<K,V>> renamed to private asSetEntryIterator(set Set<K>, function Function<? super K,V>) : Iterator<Entry<K,V>> in class com.google.common.collect.Maps |
From |
To |
|
Rename Method public stopAsync() : Service renamed to public stopAndWait() : State in class com.google.common.util.concurrent.AbstractIdleService |
From |
To |
|
Rename Method public stringConverter(enumClass Class<T>) : Converter<String,T> renamed to public valueOfFunction(enumClass Class<T>) : Function<String,T> in class com.google.common.base.Enums |
From |
To |
|
Rename Method public startAsync() : Service renamed to public start() : ListenableFuture<State> in class com.google.common.util.concurrent.AbstractService |
From |
To |
|
Rename Method package newArtificialTypeVariable(declaration D, name String, bounds Type...) : TypeVariable<D> renamed to package newTypeVariable(declaration D, name String, bounds Type...) : TypeVariable<D> in class com.google.common.reflect.Types |
From |
To |
|
Rename Method public startAsync() : Service renamed to public stop() : ListenableFuture<State> in class com.google.common.util.concurrent.AbstractScheduledService |
From |
To |
|
Move And Inline Method public close() : void moved from class com.google.common.io.CountingOutputStream to class com.google.common.io.Files.FileByteSource & inlined to public read() : byte[] |
From |
To |
|
Move And Inline Method public getKey() : K moved from class com.google.common.collect.LinkedListMultimap.Node to class com.google.common.collect.ImmutableMap & inlined to public copyOf(map Map<? extends K,? extends V>) : ImmutableMap<K,V> |
From |
To |
|
Move And Inline Method package startupTimes() : ImmutableMap<Service,Long> moved from class com.google.common.util.concurrent.ServiceManager.ServiceManagerState to class com.google.common.util.concurrent.ServiceManager & inlined to public startupTimes() : ImmutableMap<Service,Long> |
From |
To |
|
Move And Inline Method package matchesValue(v Object, smearedVHash int) : boolean moved from class com.google.common.collect.LinkedHashMultimap.ValueEntry to class com.google.common.collect.LinkedHashMultimap.ValueSet & inlined to public remove(o Object) : boolean |
From |
To |
|
Move And Inline Method public hasNext() : boolean moved from class com.google.common.collect.Iterators.MergingIterator to class com.google.common.collect.Iterators & inlined to public get(iterator Iterator<T>, position int) : T |
From |
To |
|
Move And Inline Method package keyPredicateOnEntries(keyPredicate Predicate<? super K>) : Predicate<Entry<K,?>> moved from class com.google.common.collect.Maps to class com.google.common.collect.FilteredKeyMultimap & inlined to package entryPredicate() : Predicate<? super Entry<K,V>> |
From |
To |
|
Move And Inline Method package createValues() : ImmutableCollection<V> moved from class com.google.common.collect.RegularImmutableTable to class com.google.common.collect.Maps.ImprovedAbstractMap & inlined to public values() : Collection<V> |
From |
To |
|
Move And Inline Method public unfiltered() : Multimap<K,V> moved from class com.google.common.collect.FilteredKeyMultimap to class com.google.common.collect.Sets.FilteredNavigableSet & inlined to public pollLast() : E |
From |
To |
|
Move And Inline Method package removeFirstMatching(removeFrom Iterable<T>, predicate Predicate<? super T>) : T moved from class com.google.common.collect.Iterables to class com.google.common.collect.Sets.FilteredNavigableSet & inlined to public pollFirst() : E |
From |
To |
|
Move And Inline Method package asImmutableList(elements Object[], length int) : ImmutableList<E> moved from class com.google.common.collect.ImmutableList to class com.google.common.collect.ImmutableList.Builder & inlined to public build() : ImmutableList<E> |
From |
To |
|
Move And Inline Method package withType() : Optional<T> moved from class com.google.common.base.Absent to class com.google.common.base.Optional & inlined to public absent() : Optional<T> |
From |
To |
|
Move And Inline Method public unfiltered() : Multimap<K,V> moved from class com.google.common.collect.FilteredKeyMultimap to class com.google.common.collect.Sets.FilteredNavigableSet & inlined to public pollFirst() : E |
From |
To |
|
Move And Inline Method package valueIterator() : Iterator<V> moved from class com.google.common.collect.AbstractMultimap to class com.google.common.collect.ImmutableMultimap.Values & inlined to public iterator() : UnmodifiableIterator<V> |
From |
To |
|
Move And Inline Method package readFile(in InputStream, expectedSize long) : byte[] moved from class com.google.common.io.Files to class com.google.common.io.Files.FileByteSource & inlined to public read() : byte[] |
From |
To |
|
Move And Inline Method public getKey() : K moved from class com.google.common.collect.LinkedListMultimap.Node to class com.google.common.collect.AbstractMapBasedMultiset & inlined to package entryIterator() : Iterator<Entry<E>> |
From |
To |
|
Move And Inline Method package matchesValue(v Object, smearedVHash int) : boolean moved from class com.google.common.collect.LinkedHashMultimap.ValueEntry to class com.google.common.collect.LinkedHashMultimap.ValueSet & inlined to public contains(o Object) : boolean |
From |
To |
|
Move And Inline Method package equalsImpl(multimap Multimap<?,?>, object Object) : boolean moved from class com.google.common.collect.Multimaps to class com.google.common.collect.AbstractMultimap & inlined to public equals(object Object) : boolean |
From |
To |
|
Move And Inline Method package matchesValue(v Object, smearedVHash int) : boolean moved from class com.google.common.collect.LinkedHashMultimap.ValueEntry to class com.google.common.collect.LinkedHashMultimap.ValueSet & inlined to public add(value V) : boolean |
From |
To |
|
Move And Inline Method package servicesByState() : ImmutableMultimap<State,Service> moved from class com.google.common.util.concurrent.ServiceManager.ServiceManagerState to class com.google.common.util.concurrent.ServiceManager & inlined to public servicesByState() : ImmutableMultimap<State,Service> |
From |
To |
|
Move And Inline Method package removeFirstMatching(removeFrom Iterable<T>, predicate Predicate<? super T>) : T moved from class com.google.common.collect.Iterables to class com.google.common.collect.Sets.FilteredNavigableSet & inlined to public pollLast() : E |
From |
To |
|
Move And Inline Method package equalsImpl(multimap Multimap<?,?>, object Object) : boolean moved from class com.google.common.collect.Multimaps to class com.google.common.collect.ImmutableMultiset & inlined to public equals(object Object) : boolean |
From |
To |
|
Move And Inline Method package map() : Map<K,V> moved from class com.google.common.collect.Maps.KeySet to class com.google.common.collect.AbstractMapBasedMultimap.SortedKeySet & inlined to package sortedMap() : SortedMap<K,Collection<V>> |
From |
To |
|
Move And Inline Method public getValue() : V moved from class com.google.common.collect.LinkedListMultimap.Node to class com.google.common.collect.ImmutableMap.Builder & inlined to public put(entry Entry<? extends K,? extends V>) : Builder<K,V> |
From |
To |
|
Move Method public fromInt(hash int) : HashCode from class com.google.common.hash.HashCode to public fromInt(hash int) : HashCode from class com.google.common.hash.HashCodes |
From |
To |
|
Move Method public size() : int from class com.google.common.collect.ImmutableMultiset.EntrySet to public size() : int from class com.google.common.collect.ArrayTable.CellSet |
From |
To |
|
Move Method public remove(o Object) : boolean from class com.google.common.collect.FilteredMultimapValues to public remove(o Object) : boolean from class com.google.common.collect.Sets.SetFromMap |
From |
To |
|
Move Method private getLockName(rank Enum<?>) : String from class com.google.common.util.concurrent.CycleDetectingLockFactory to private getLockName(rank Enum<?>) : String from class com.google.common.util.concurrent.CycleDetectingLockFactory.OrderedLockGraphNodesCreator |
From |
To |
|
Move Method public size() : int from class com.google.common.collect.Maps.FilteredEntryNavigableMap to public size() : int from class com.google.common.collect.ArrayTable.CellSet |
From |
To |
|
Move Method package createAsList() : ImmutableList<Entry<E>> from class com.google.common.collect.ImmutableMultiset.EntrySet to package createAsList() : ImmutableList<Entry<E>> from class com.google.common.collect.RegularImmutableMultiset.EntrySet |
From |
To |
|
Move Method public size() : int from class com.google.common.cache.LocalCache.Values to public size() : int from class com.google.common.collect.EmptyImmutableList |
From |
To |
|
Move Method public clear() : void from class com.google.common.collect.AbstractMultimap.Values to public clear() : void from class com.google.common.collect.Sets.SetFromMap |
From |
To |
|
Move Method public isEmpty() : boolean from class com.google.common.cache.LocalCache.Values to public isEmpty() : boolean from class com.google.common.collect.EmptyImmutableList |
From |
To |
|
Move Method public containsKey(key Object) : boolean from class com.google.common.collect.Maps.FilteredEntryNavigableMap to public containsKey(key Object) : boolean from class com.google.common.collect.Multimaps.MapMultimap.AsMap |
From |
To |
|
Move Method public clear() : void from class com.google.common.collect.Maps.FilteredEntryNavigableMap to public clear() : void from class com.google.common.collect.Maps.AbstractFilteredMap.Values |
From |
To |
|
Move Method package fromBytesNoCopy(bytes byte[]) : HashCode from class com.google.common.hash.HashCode to package fromBytesNoCopy(bytes byte[]) : HashCode from class com.google.common.hash.HashCodes |
From |
To |
|
Move Method public fromBytes(bytes byte[]) : HashCode from class com.google.common.hash.HashCode to public fromBytes(bytes byte[]) : HashCode from class com.google.common.hash.HashCodes |
From |
To |
|
Move Method public retainAll(c Collection<?>) : boolean from class com.google.common.collect.FilteredMultimapValues to public retainAll(c Collection<?>) : boolean from class com.google.common.collect.Sets.SetFromMap |
From |
To |
|
Move Method public removeAll(c Collection<?>) : boolean from class com.google.common.collect.FilteredMultimapValues to public removeAll(c Collection<?>) : boolean from class com.google.common.collect.Sets.SetFromMap |
From |
To |
|
Move Method public fromLong(hash long) : HashCode from class com.google.common.hash.HashCode to public fromLong(hash long) : HashCode from class com.google.common.hash.HashCodes |
From |
To |
|
Move Method public iterator() : UnmodifiableIterator<Entry<E>> from class com.google.common.collect.ImmutableMultiset.EntrySet to public iterator() : UnmodifiableIterator<Entry<E>> from class com.google.common.collect.RegularImmutableMultiset.EntrySet |
From |
To |
|
Move Method public isEmpty() : boolean from class com.google.common.collect.Maps.FilteredEntryNavigableMap to public isEmpty() : boolean from class com.google.common.collect.EmptyImmutableList |
From |
To |
|
Move Method public contains(o Object) : boolean from class com.google.common.collect.AbstractMultimap.Values to public contains(o Object) : boolean from class com.google.common.collect.Sets.SetFromMap |
From |
To |
|
Change Variable Type onlyEntry : Entry<K,V> to enumMap : EnumMap<?,?> in method public copyOf(map Map<? extends K,? extends V>) : ImmutableMap<K,V> in class com.google.common.collect.ImmutableMap |
From |
To |
|
Change Variable Type wrappers : Set<EventSubscriber> to wrappers : Set<EventHandler> in method public post(event Object) : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Change Variable Type mappings : Map<TypeVariableKey,Type> to mappings : Map<TypeVariable<?>,Type> in method public where(formal Type, actual Type) : TypeResolver in class com.google.common.reflect.TypeResolver |
From |
To |
|
Change Variable Type wrapper : EventSubscriber to wrapper : EventHandler in method public post(event Object) : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Change Variable Type methodsInListener : Multimap<Class<?>,EventSubscriber> to methodsInListener : Multimap<Class<?>,EventHandler> in method public findAllHandlers(listener Object) : Multimap<Class<?>,EventHandler> in class com.google.common.eventbus.AnnotatedHandlerFinder |
From |
To |
|
Change Variable Type events : Queue<EventWithSubscriber> to events : Queue<EventWithHandler> in method package dispatchQueuedEvents() : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Change Variable Type newEntry : ImmutableMapEntry<K,V> to newEntry : BiMapEntry<K,V> in method package RegularImmutableBiMap(entriesToAdd Collection<? extends Entry<? extends K,? extends V>>) in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Change Variable Type in : FileInputStream to in : InputStream in method public read() : byte[] in class com.google.common.io.Files.FileByteSource |
From |
To |
|
Change Variable Type eventWithSubscriber : EventWithSubscriber to eventWithHandler : EventWithHandler in method package dispatchQueuedEvents() : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Change Variable Type entry : Entry<E> to entry : Entry<?> in method package SerializedForm(multiset SortedMultiset<?>) in class com.google.common.collect.ImmutableSortedMultiset.SerializedForm |
From |
To |
|
Change Variable Type nextInKeyBucket : ImmutableMapEntry<K,V> to nextInKToVBucket : BiMapEntry<K,V> in method package RegularImmutableBiMap(entriesToAdd Collection<? extends Entry<? extends K,? extends V>>) in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Change Variable Type entry : ImmutableMapEntry<K,V> to entry : BiMapEntry<K,V> in method public get(key Object) : V in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Change Variable Type rawParamTypes : Class<?>[] to declaringClass : Class<?> in method package getGenericParameterTypes() : Type[] in class com.google.common.reflect.Invokable.ConstructorInvokable |
From |
To |
|
Change Variable Type count : Count to count : int in method public getCount() : int in class com.google.common.collect.AbstractMapBasedMultiset.entryIterator.next |
From |
To |
|
Change Variable Type existing : ImmutableMapEntry<K,V> to existing : LinkedEntry<K,V> in method package RegularImmutableMap(immutableEntries Entry<?,?>...) in class com.google.common.collect.RegularImmutableMap |
From |
To |
|
Change Variable Type that : EventSubscriber to that : EventHandler in method public equals(obj Object) : boolean in class com.google.common.eventbus.EventHandler |
From |
To |
|
Change Variable Type eventMethodsInListener : Collection<EventSubscriber> to eventMethodsInListener : Collection<EventHandler> in method public unregister(object Object) : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Change Variable Type valueTable : ImmutableMapEntry<K,V>[] to vToKTable : BiMapEntry<K,V>[] in method package RegularImmutableBiMap(entriesToAdd Collection<? extends Entry<? extends K,? extends V>>) in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Change Variable Type entry : Map.Entry<K,? extends V> to entry : Map.Entry<K,V> in method public immutableEnumMap(map Map<K,V>) : ImmutableMap<K,V> in class com.google.common.collect.Maps |
From |
To |
|
Change Variable Type subscriber : EventSubscriber to handler : EventHandler in method public findAllHandlers(listener Object) : Multimap<Class<?>,EventHandler> in class com.google.common.eventbus.AnnotatedHandlerFinder |
From |
To |
|
Change Variable Type entries : Entry<?,?>[] to entries : Entry<K,V>[] in method public copyOf(map Map<? extends K,? extends V>) : ImmutableMap<K,V> in class com.google.common.collect.ImmutableMap |
From |
To |
|
Change Variable Type nextInValueBucket : ImmutableMapEntry<K,V> to nextInVToKBucket : BiMapEntry<K,V> in method package RegularImmutableBiMap(entriesToAdd Collection<? extends Entry<? extends K,? extends V>>) in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Change Variable Type currentSubscribers : Set<EventSubscriber> to currentHandlers : Set<EventHandler> in method public unregister(object Object) : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Change Variable Type eventWithSubscriber : EventWithSubscriber to eventWithHandler : EventWithHandler in method protected dispatchQueuedEvents() : void in class com.google.common.eventbus.AsyncEventBus |
From |
To |
|
Change Variable Type methodsInListener : Multimap<Class<?>,EventSubscriber> to methodsInListener : Multimap<Class<?>,EventHandler> in method public register(object Object) : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Change Variable Type newEntry : ImmutableMapEntry<K,V> to linkedEntry : LinkedEntry<K,V> in method package RegularImmutableMap(immutableEntries Entry<?,?>...) in class com.google.common.collect.RegularImmutableMap |
From |
To |
|
Change Variable Type keyTable : ImmutableMapEntry<K,V>[] to kToVTable : BiMapEntry<K,V>[] in method package RegularImmutableBiMap(entriesToAdd Collection<? extends Entry<? extends K,? extends V>>) in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Change Variable Type entries : ImmutableMapEntry<K,V>[] to entries : BiMapEntry<K,V>[] in method package RegularImmutableBiMap(entriesToAdd Collection<? extends Entry<? extends K,? extends V>>) in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Change Variable Type entry : ImmutableMapEntry<K,V> to entry : BiMapEntry<K,V> in method public get(value Object) : K in class com.google.common.collect.RegularImmutableBiMap.Inverse |
From |
To |
|
Change Variable Type result : Map<R,Map<C,V>> to result : RowMap in method public rowMap() : Map<R,Map<C,V>> in class com.google.common.collect.StandardTable |
From |
To |
|
Change Variable Type bitCount : long to bitCount : int in method package BitArray(data long[]) in class com.google.common.hash.BloomFilterStrategies.BitArray |
From |
To |
|
Change Variable Type hc : int[] to hc : HashCode in method public add(x long) : void in class com.google.common.cache.LongAdder |
From |
To |
|
Change Variable Type entry : ImmutableMapEntry<K,V> to entry : LinkedEntry<K,V> in method public get(key Object) : V in class com.google.common.collect.RegularImmutableMap |
From |
To |
|
Change Variable Type out : Writer to out : BufferedWriter in method public writeLines(lines Iterable<? extends CharSequence>, lineSeparator String) : void in class com.google.common.io.CharSink |
From |
To |
|
Change Variable Type wrapper : EventSubscriber to wrapper : EventHandler in method private makeHandler(listener Object, method Method) : EventHandler in class com.google.common.eventbus.AnnotatedHandlerFinder |
From |
To |
|
Change Variable Type methodsInListener : Multimap<Class<?>,EventSubscriber> to methodsInListener : Multimap<Class<?>,EventHandler> in method public unregister(object Object) : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Change Variable Type entry : Entry<Class<?>,Collection<EventSubscriber>> to entry : Entry<Class<?>,Collection<EventHandler>> in method public unregister(object Object) : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Inline Method package asImmutableList(elements Object[], length int) : ImmutableList<E> inlined to package asImmutableList(elements Object[]) : ImmutableList<E> in class com.google.common.collect.ImmutableList |
From |
To |
|
Inline Method public newDataOutput(byteArrayOutputSteam ByteArrayOutputStream) : ByteArrayDataOutput inlined to public newDataOutput() : ByteArrayDataOutput in class com.google.common.io.ByteStreams |
From |
To |
|
Inline Method public newDataOutput(byteArrayOutputSteam ByteArrayOutputStream) : ByteArrayDataOutput inlined to public newDataOutput(size int) : ByteArrayDataOutput in class com.google.common.io.ByteStreams |
From |
To |
|
Inline Method package reserve(permits int) : long inlined to public acquire(permits int) : void in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Inline Method private asAsyncFunction(function Function<? super I,? extends O>) : AsyncFunction<I,O> inlined to public transform(input ListenableFuture<I>, function Function<? super I,? extends O>, executor Executor) : ListenableFuture<O> in class com.google.common.util.concurrent.Futures |
From |
To |
|
Inline Method package fromEntries(comparator Comparator<? super K>, sameComparator boolean, size int, entries Entry<K,V>...) : ImmutableSortedMap<K,V> inlined to private copyOfInternal(map Map<? extends K,? extends V>, comparator Comparator<? super K>) : ImmutableSortedMap<K,V> in class com.google.common.collect.ImmutableSortedMap |
From |
To |
|
Inline Method private mayNeedHiddenThis() : boolean inlined to package getGenericParameterTypes() : Type[] in class com.google.common.reflect.Invokable.ConstructorInvokable |
From |
To |
|
Inline Method private sliceStream(in InputStream) : InputStream inlined to public openStream() : InputStream in class com.google.common.io.ByteSource.SlicedByteSource |
From |
To |
|
Inline Method private valueSet(valueComparator Comparator<? super V>, values Collection<? extends V>) : ImmutableSet<V> inlined to private copyOf(multimap Multimap<? extends K,? extends V>, valueComparator Comparator<? super V>) : ImmutableSetMultimap<K,V> in class com.google.common.collect.ImmutableSetMultimap |
From |
To |
|
Inline Method private isProxyOfSameInterfaces(arg Object, proxyClass Class<?>) : boolean inlined to public invoke(proxy Object, method Method, args Object[]) : Object in class com.google.common.reflect.AbstractInvocationHandler |
From |
To |
|
Inline Method private doDifference(left Map<? extends K,? extends V>, right Map<? extends K,? extends V>, valueEquivalence Equivalence<? super V>, onlyOnLeft Map<K,V>, onlyOnRight Map<K,V>, onBoth Map<K,V>, differences Map<K,MapDifference.ValueDifference<V>>) : void inlined to public difference(left Map<? extends K,? extends V>, right Map<? extends K,? extends V>, valueEquivalence Equivalence<? super V>) : MapDifference<K,V> in class com.google.common.collect.Maps |
From |
To |
|
Inline Method public newDataInput(byteArrayInputStream ByteArrayInputStream) : ByteArrayDataInput inlined to public newDataInput(bytes byte[]) : ByteArrayDataInput in class com.google.common.io.ByteStreams |
From |
To |
|
Inline Method package decodeChecked(chars CharSequence) : byte[] inlined to public decode(chars CharSequence) : byte[] in class com.google.common.io.BaseEncoding |
From |
To |
|
Inline Method private removeIf(keyPredicate Predicate<? super K>) : boolean inlined to public retainAll(collection Collection<?>) : boolean in class com.google.common.collect.Maps.FilteredEntryMap.KeySet |
From |
To |
|
Inline Method private copyOfEnumSet(enumSet EnumSet<E>) : ImmutableSet<E> inlined to public copyOf(elements Collection<? extends E>) : ImmutableSet<E> in class com.google.common.collect.ImmutableSet |
From |
To |
|
Rename Variable satisfied : boolean to success : boolean in method public enterWhenUninterruptibly(guard Guard) : void in class com.google.common.util.concurrent.Monitor |
From |
To |
|
Rename Variable bucket : int to row : int in method public remove(o Object) : boolean in class com.google.common.collect.LinkedHashMultimap.ValueSet |
From |
To |
|
Rename Variable eventWithSubscriber : EventWithSubscriber to eventWithHandler : EventWithHandler in method package dispatchQueuedEvents() : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Rename Variable bucket : int to row : int in method public add(value V) : boolean in class com.google.common.collect.LinkedHashMultimap.ValueSet |
From |
To |
|
Rename Variable rawParamTypes : Class<?>[] to declaringClass : Class<?> in method package getGenericParameterTypes() : Type[] in class com.google.common.reflect.Invokable.ConstructorInvokable |
From |
To |
|
Rename Variable newValue : V to value : V in method public iterator() : Iterator<Entry<K,V>> in class com.google.common.collect.Maps.FilteredEntryMap.EntrySet |
From |
To |
|
Rename Variable secondMultiset : Multiset<?> to secondSet : Multiset<?> in method private isPermutation(first List<?>, second List<?>) : boolean in class com.google.common.collect.Collections2 |
From |
To |
|
Rename Variable separatorLength : int to delimeterLength : int in method public on(separator String) : Splitter in class com.google.common.base.Splitter |
From |
To |
|
Rename Variable canRemoveOrSet : boolean to canSet : boolean in method public listIterator(index int) : ListIterator<T> in class com.google.common.collect.Lists.ReverseList |
From |
To |
|
Rename Variable onlyEntry : Entry<K,V> to enumMap : EnumMap<?,?> in method public copyOf(map Map<? extends K,? extends V>) : ImmutableMap<K,V> in class com.google.common.collect.ImmutableMap |
From |
To |
|
Rename Variable satisfied : boolean to success : boolean in method public enterWhen(guard Guard) : void in class com.google.common.util.concurrent.Monitor |
From |
To |
|
Rename Variable subscriber : EventSubscriber to handler : EventHandler in method public findAllHandlers(listener Object) : Multimap<Class<?>,EventHandler> in class com.google.common.eventbus.AnnotatedHandlerFinder |
From |
To |
|
Rename Variable c : Collection<? extends T> to collection : Collection<? extends T> in method public getLast(iterable Iterable<? extends T>, defaultValue T) : T in class com.google.common.collect.Iterables |
From |
To |
|
Rename Variable smearedHash : int to hash : int in method public add(value V) : boolean in class com.google.common.collect.LinkedHashMultimap.ValueSet |
From |
To |
|
Rename Variable currentSubscribers : Set<EventSubscriber> to currentHandlers : Set<EventHandler> in method public unregister(object Object) : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Rename Variable bucket : int to row : int in method private rehashIfNecessary() : void in class com.google.common.collect.LinkedHashMultimap.ValueSet |
From |
To |
|
Rename Variable interrupted : boolean to interruptIgnored : boolean in method public enter(time long, unit TimeUnit) : boolean in class com.google.common.util.concurrent.Monitor |
From |
To |
|
Rename Variable nextInKeyBucket : ImmutableMapEntry<K,V> to nextInKToVBucket : BiMapEntry<K,V> in method package RegularImmutableBiMap(entriesToAdd Collection<? extends Entry<? extends K,? extends V>>) in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Rename Variable timeoutNanos : long to remainingNanos : long in method public enterWhen(guard Guard, time long, unit TimeUnit) : boolean in class com.google.common.util.concurrent.Monitor |
From |
To |
|
Rename Variable firstMultiset : Multiset<?> to firstSet : Multiset<?> in method private isPermutation(first List<?>, second List<?>) : boolean in class com.google.common.collect.Collections2 |
From |
To |
|
Rename Variable valueTable : ImmutableMapEntry<K,V>[] to vToKTable : BiMapEntry<K,V>[] in method package RegularImmutableBiMap(entriesToAdd Collection<? extends Entry<? extends K,? extends V>>) in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Rename Variable signalBeforeWaiting : boolean to reentrant : boolean in method public enterWhen(guard Guard) : void in class com.google.common.util.concurrent.Monitor |
From |
To |
|
Rename Variable nextInValueBucket : ImmutableMapEntry<K,V> to nextInVToKBucket : BiMapEntry<K,V> in method package RegularImmutableBiMap(entriesToAdd Collection<? extends Entry<? extends K,? extends V>>) in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Rename Variable args : Type[] to vars : Type[] in method private resolveParameterizedType(type ParameterizedType) : ParameterizedType in class com.google.common.reflect.TypeResolver |
From |
To |
|
Rename Variable eventWithSubscriber : EventWithSubscriber to eventWithHandler : EventWithHandler in method protected dispatchQueuedEvents() : void in class com.google.common.eventbus.AsyncEventBus |
From |
To |
|
Rename Variable signalBeforeWaiting : boolean to reentrant : boolean in method public enterWhenUninterruptibly(guard Guard) : void in class com.google.common.util.concurrent.Monitor |
From |
To |
|
Rename Variable newEntry : ImmutableMapEntry<K,V> to linkedEntry : LinkedEntry<K,V> in method package RegularImmutableMap(immutableEntries Entry<?,?>...) in class com.google.common.collect.RegularImmutableMap |
From |
To |
|
Rename Variable keyTable : ImmutableMapEntry<K,V>[] to kToVTable : BiMapEntry<K,V>[] in method package RegularImmutableBiMap(entriesToAdd Collection<? extends Entry<? extends K,? extends V>>) in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Rename Variable array : E[] to elements : E[] in method public immutableSortedCopy(iterable Iterable<E>) : ImmutableList<E> in class com.google.common.collect.Ordering |
From |
To |
|
Rename Variable signalBeforeWaiting : boolean to reentrant : boolean in method public enterWhenUninterruptibly(guard Guard, time long, unit TimeUnit) : boolean in class com.google.common.util.concurrent.Monitor |
From |
To |
|
Change Return Type void to boolean in method package awaitHealthy(timeout long, unit TimeUnit) : boolean in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState |
From |
To |
|
Change Return Type Optional<T> to Optional<Object> in method public or(secondChoice Optional<?>) : Optional<Object> in class com.google.common.base.Absent |
From |
To |
|
Change Return Type OutputStream to BufferedOutputStream in method public openBufferedStream() : BufferedOutputStream in class com.google.common.io.ByteSink |
From |
To |
|
Change Return Type double to void in method public acquire() : void in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Change Return Type ImmutableMap<TypeVariableKey,Type> to ImmutableMap<TypeVariable<?>,Type> in method package getTypeMappings(contextType Type) : ImmutableMap<TypeVariable<?>,Type> in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector |
From |
To |
|
Change Return Type ListenableScheduledFuture<?> to ScheduledFuture<?> in method public scheduleAtFixedRate(command Runnable, initialDelay long, period long, unit TimeUnit) : ScheduledFuture<?> in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator |
From |
To |
|
Change Return Type Service to State in method public stopAndWait() : State in class com.google.common.util.concurrent.AbstractExecutionThreadService |
From |
To |
|
Change Return Type long to int in method package bitCount() : int in class com.google.common.hash.BloomFilterStrategies.BitArray |
From |
To |
|
Change Return Type SortedSet<K> to SortedSet<R> in method public headSet(toElement R) : SortedSet<R> in class com.google.common.collect.StandardRowSortedTable.RowKeySortedSet |
From |
To |
|
Change Return Type ListenableScheduledFuture<?> to ScheduledFuture<?> in method public scheduleWithFixedDelay(command Runnable, initialDelay long, delay long, unit TimeUnit) : ScheduledFuture<?> in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator |
From |
To |
|
Change Return Type ImmutableMapEntry<K,V>[] to LinkedEntry<K,V>[] in method private createEntryArray(size int) : LinkedEntry<K,V>[] in class com.google.common.collect.RegularImmutableMap |
From |
To |
|
Change Return Type Converter<String,T> to Function<String,T> in method public valueOfFunction(enumClass Class<T>) : Function<String,T> in class com.google.common.base.Enums |
From |
To |
|
Change Return Type Service to State in method public stopAndWait() : State in class com.google.common.util.concurrent.AbstractIdleService |
From |
To |
|
Change Return Type T to Object in method public or(defaultValue Object) : Object in class com.google.common.base.Absent |
From |
To |
|
Change Return Type Multimap<Class<?>,EventSubscriber> to Multimap<Class<?>,EventHandler> in method public findAllHandlers(listener Object) : Multimap<Class<?>,EventHandler> in class com.google.common.eventbus.AnnotatedHandlerFinder |
From |
To |
|
Change Return Type Writer to BufferedWriter in method public openBufferedStream() : BufferedWriter in class com.google.common.io.CharSink |
From |
To |
|
Change Return Type T to Object in method public or(supplier Supplier<?>) : Object in class com.google.common.base.Absent |
From |
To |
|
Change Return Type T to Object in method public orNull() : Object in class com.google.common.base.Absent |
From |
To |
|
Change Return Type SortedSet<K> to SortedSet<R> in method public subSet(fromElement R, toElement R) : SortedSet<R> in class com.google.common.collect.StandardRowSortedTable.RowKeySortedSet |
From |
To |
|
Change Return Type Set<T> to Set<Object> in method public asSet() : Set<Object> in class com.google.common.base.Absent |
From |
To |
|
Change Return Type Service to ListenableFuture<State> in method public start() : ListenableFuture<State> in class com.google.common.util.concurrent.Service |
From |
To |
|
Change Return Type TerminalEntry<K,V> to Entry<K,V> in method package entryOf(key K, value V) : Entry<K,V> in class com.google.common.collect.ImmutableMap |
From |
To |
|
Change Return Type K to R in method public last() : R in class com.google.common.collect.StandardRowSortedTable.RowKeySortedSet |
From |
To |
|
Change Return Type InputStream to BufferedInputStream in method public openBufferedStream() : BufferedInputStream in class com.google.common.io.ByteSource |
From |
To |
|
Change Return Type ImmutableMapEntry<K,V> to BiMapEntry<K,V> in method package getNextInVToKBucket() : BiMapEntry<K,V> in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry |
From |
To |
|
Change Return Type long to int in method package size() : int in class com.google.common.hash.BloomFilterStrategies.BitArray |
From |
To |
|
Change Return Type Service to ListenableFuture<State> in method public stop() : ListenableFuture<State> in class com.google.common.util.concurrent.AbstractScheduledService |
From |
To |
|
Change Return Type double to void in method public acquire(permits int) : void in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Change Return Type EventSubscriber to EventHandler in method private makeHandler(listener Object, method Method) : EventHandler in class com.google.common.eventbus.AnnotatedHandlerFinder |
From |
To |
|
Change Return Type Entry<E> to ImmutableSet<Entry<E>> in method package abstract createEntrySet() : ImmutableSet<Entry<E>> in class com.google.common.collect.ImmutableMultiset |
From |
To |
|
Change Return Type Entry<E> to ImmutableSet<Entry<E>> in method package createEntrySet() : ImmutableSet<Entry<E>> in class com.google.common.collect.EmptyImmutableSortedMultiset |
From |
To |
|
Change Return Type Service to State in method public stopAndWait() : State in class com.google.common.util.concurrent.AbstractScheduledService |
From |
To |
|
Change Return Type int to void in method private checkPermits(permits int) : void in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Change Return Type Service to ListenableFuture<State> in method public stop() : ListenableFuture<State> in class com.google.common.util.concurrent.AbstractIdleService |
From |
To |
|
Change Return Type Comparator<? super K> to Comparator<? super R> in method public comparator() : Comparator<? super R> in class com.google.common.collect.StandardRowSortedTable.RowKeySortedSet |
From |
To |
|
Change Return Type Iterator<Iterator<? extends T>> to UnmodifiableIterator<Iterator<? extends T>> in method private iterators(iterables Iterable<? extends Iterable<? extends T>>) : UnmodifiableIterator<Iterator<? extends T>> in class com.google.common.collect.Iterables |
From |
To |
|
Change Return Type ImmutableMapEntry<K,V>[] to BiMapEntry<K,V>[] in method private createEntryArray(length int) : BiMapEntry<K,V>[] in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Change Return Type SortedSet<K> to SortedSet<R> in method public tailSet(fromElement R) : SortedSet<R> in class com.google.common.collect.StandardRowSortedTable.RowKeySortedSet |
From |
To |
|
Change Return Type Service to ListenableFuture<State> in method public stop() : ListenableFuture<State> in class com.google.common.util.concurrent.AbstractExecutionThreadService |
From |
To |
|
Change Return Type ListenableScheduledFuture<?> to ScheduledFuture<?> in method public schedule(command Runnable, delay long, unit TimeUnit) : ScheduledFuture<?> in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator |
From |
To |
|
Change Return Type K to R in method public first() : R in class com.google.common.collect.StandardRowSortedTable.RowKeySortedSet |
From |
To |
|
Change Return Type ListenableScheduledFuture<V> to ScheduledFuture<V> in method public schedule(callable Callable<V>, delay long, unit TimeUnit) : ScheduledFuture<V> in class com.google.common.util.concurrent.MoreExecutors.ScheduledListeningDecorator |
From |
To |
|
Change Return Type Service to ListenableFuture<State> in method public stop() : ListenableFuture<State> in class com.google.common.util.concurrent.Service |
From |
To |
|
Change Return Type T to Object in method public get() : Object in class com.google.common.base.Absent |
From |
To |
|
Change Return Type void to boolean in method package awaitStopped(timeout long, unit TimeUnit) : boolean in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState |
From |
To |
|
Change Return Type Iterator<Table.Cell<R,C,V>> to Iterator<Cell<R,C,V>> in method public iterator() : Iterator<Cell<R,C,V>> in class com.google.common.collect.StandardTable.CellSet |
From |
To |
|
Change Return Type Service to ListenableFuture<State> in method public start() : ListenableFuture<State> in class com.google.common.util.concurrent.AbstractService |
From |
To |
|
Change Return Type Service to State in method public stopAndWait() : State in class com.google.common.util.concurrent.Service |
From |
To |
|
Rename Attribute subscriber : EventSubscriber to handler : EventHandler in class com.google.common.eventbus.EventBus.EventWithHandler |
From |
To |
|
Rename Attribute source : ByteSource to supplier : InputSupplier<InputStream> in class com.google.common.io.FileBackedOutputStream |
From |
To |
|
Rename Attribute smearedValueHash : int to valueHash : int in class com.google.common.collect.LinkedHashMultimap.ValueEntry |
From |
To |
|
Rename Attribute valueTable : ImmutableMapEntry<K,V>[] to vToKTable : BiMapEntry<K,V>[] in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Rename Attribute subscribersByTypeLock : ReadWriteLock to handlersByTypeLock : ReadWriteLock in class com.google.common.eventbus.EventBus |
From |
To |
|
Rename Attribute nextInValueBucket : ImmutableMapEntry<K,V> to nextInVToKBucket : BiMapEntry<K,V> in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry |
From |
To |
|
Rename Attribute stopwatch : SleepingStopwatch to ticker : SleepingTicker in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Rename Attribute subscriberMethodsCache : LoadingCache<Class<?>,ImmutableList<Method>> to handlerMethodsCache : LoadingCache<Class<?>,ImmutableList<Method>> in class com.google.common.eventbus.AnnotatedHandlerFinder |
From |
To |
|
Rename Attribute charsetCanonicalName : String to elements : Object[] in class com.google.common.collect.ImmutableCollection.SerializedForm |
From |
To |
|
Rename Attribute keyTable : ImmutableMapEntry<K,V>[] to kToVTable : BiMapEntry<K,V>[] in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Rename Attribute subscribersByType : SetMultimap<Class<?>,EventSubscriber> to handlersByType : SetMultimap<Class<?>,EventHandler> in class com.google.common.eventbus.EventBus |
From |
To |
|
Rename Attribute seq : CharSequence to string : String in class com.google.common.io.CharStreams.StringCharSource |
From |
To |
|
Rename Attribute TYPE_NAME : Function<Type,String> to TYPE_TO_STRING : Function<Type,String> in class com.google.common.reflect.Types |
From |
To |
|
Rename Attribute nextInKeyBucket : ImmutableMapEntry<K,V> to nextInKToVBucket : BiMapEntry<K,V> in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry |
From |
To |
|
Rename Attribute nextInValueBucket : ValueEntry<K,V> to nextInValueSetHashRow : ValueEntry<K,V> in class com.google.common.collect.LinkedHashMultimap.ValueEntry |
From |
To |
|
Change Attribute Type valueTable : ImmutableMapEntry<K,V>[] to vToKTable : BiMapEntry<K,V>[] in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Change Attribute Type mapper : Function<? super Exception,X> to mapper : Function<Exception,X> in class com.google.common.util.concurrent.Futures.MappingCheckedFuture |
From |
To |
|
Change Attribute Type EXACT : ImmutableMap<String,PublicSuffixType> to EXACT : ImmutableSet<String> in class com.google.common.net.TldPatterns |
From |
To |
|
Change Attribute Type rowMap : Map<R,Map<C,V>> to rowMap : RowMap in class com.google.common.collect.StandardTable |
From |
To |
|
Change Attribute Type emptySet : ImmutableSet<V> to emptySet : ImmutableSortedSet<V> in class com.google.common.collect.ImmutableSetMultimap |
From |
To |
|
Change Attribute Type runnables : RunnableExecutorPair to runnables : Queue<RunnableExecutorPair> in class com.google.common.util.concurrent.ExecutionList |
From |
To |
|
Change Attribute Type subscribersByType : SetMultimap<Class<?>,EventSubscriber> to handlersByType : SetMultimap<Class<?>,EventHandler> in class com.google.common.eventbus.EventBus |
From |
To |
|
Change Attribute Type bitCount : long to bitCount : int in class com.google.common.hash.BloomFilterStrategies.BitArray |
From |
To |
|
Change Attribute Type entries : ImmutableMapEntry<K,V>[] to entries : LinkedEntry<K,V>[] in class com.google.common.collect.RegularImmutableMap |
From |
To |
|
Change Attribute Type entries : ImmutableMapEntry<K,V>[] to entries : BiMapEntry<K,V>[] in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Change Attribute Type source : ByteSource to supplier : InputSupplier<InputStream> in class com.google.common.io.FileBackedOutputStream |
From |
To |
|
Change Attribute Type funnel : Funnel<? super T> to funnel : Funnel<T> in class com.google.common.hash.BloomFilter |
From |
To |
|
Change Attribute Type activeGuards : Guard to activeGuards : ArrayList<Guard> in class com.google.common.util.concurrent.Monitor |
From |
To |
|
Change Attribute Type finder : SubscriberFindingStrategy to finder : HandlerFindingStrategy in class com.google.common.eventbus.EventBus |
From |
To |
|
Change Attribute Type eventsToDispatch : ConcurrentLinkedQueue<EventWithSubscriber> to eventsToDispatch : ConcurrentLinkedQueue<EventWithHandler> in class com.google.common.eventbus.AsyncEventBus |
From |
To |
|
Change Attribute Type services : ImmutableList<Service> to services : ImmutableMap<Service,ServiceListener> in class com.google.common.util.concurrent.ServiceManager |
From |
To |
|
Change Attribute Type EMPTY : ImmutableRangeMap<Comparable<?>,Object> to EMPTY : ImmutableRangeMap in class com.google.common.collect.ImmutableRangeMap |
From |
To |
|
Change Attribute Type totalWeight : long to totalWeight : int in class com.google.common.cache.LocalCache.Segment |
From |
To |
|
Change Attribute Type subscriber : EventSubscriber to handler : EventHandler in class com.google.common.eventbus.EventBus.EventWithHandler |
From |
To |
|
Change Attribute Type funnel : Funnel<? super T> to funnel : Funnel<T> in class com.google.common.hash.BloomFilter.SerialForm |
From |
To |
|
Change Attribute Type comparator : Comparator<? super E> to comparator : Comparator in class com.google.common.collect.ImmutableSortedMultiset.SerializedForm |
From |
To |
|
Change Attribute Type table : ImmutableMapEntry<K,V>[] to table : LinkedEntry<K,V>[] in class com.google.common.collect.RegularImmutableMap |
From |
To |
|
Change Attribute Type it : Iterator<? extends ByteSource> to it : Iterator<? extends InputSupplier<? extends InputStream>> in class com.google.common.io.MultiInputStream |
From |
To |
|
Change Attribute Type mappings : Map<TypeVariableKey,Type> to mappings : Map<TypeVariable<?>,Type> in class com.google.common.reflect.TypeResolver.TypeMappingIntrospector |
From |
To |
|
Change Attribute Type elements : E[] to elements : Object[] in class com.google.common.collect.ImmutableSortedMultiset.SerializedForm |
From |
To |
|
Change Attribute Type EXCLUDED : ImmutableMap<String,PublicSuffixType> to EXCLUDED : ImmutableSet<String> in class com.google.common.net.TldPatterns |
From |
To |
|
Change Attribute Type nextInValueBucket : ImmutableMapEntry<K,V> to nextInVToKBucket : BiMapEntry<K,V> in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry |
From |
To |
|
Change Attribute Type entries : TerminalEntry<K,V>[] to entries : ArrayList<Entry<K,V>> in class com.google.common.collect.ImmutableMap.Builder |
From |
To |
|
Change Attribute Type state : WeakReference<ServiceManagerState> to state : ServiceManagerState in class com.google.common.util.concurrent.ServiceManager.ServiceListener |
From |
To |
|
Change Attribute Type keyTable : ImmutableMapEntry<K,V>[] to kToVTable : BiMapEntry<K,V>[] in class com.google.common.collect.RegularImmutableBiMap |
From |
To |
|
Change Attribute Type listeners : List<ListenerCallQueue<Listener>> to listeners : List<ListenerExecutorPair> in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState |
From |
To |
|
Change Attribute Type it : Iterator<? extends CharSource> to it : Iterator<? extends InputSupplier<? extends Reader>> in class com.google.common.io.MultiReader |
From |
To |
|
Change Attribute Type inputSet : ImmutableMap<E,Integer> to inputSet : ImmutableSet<E> in class com.google.common.collect.Sets.PowerSet |
From |
To |
|
Change Attribute Type nextInKeyBucket : ImmutableMapEntry<K,V> to nextInKToVBucket : BiMapEntry<K,V> in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry |
From |
To |
|
Change Attribute Type threadHashCode : ThreadLocal<int[]> to threadHashCode : ThreadHashCode in class com.google.common.cache.Striped64 |
From |
To |
|
Change Attribute Type lockGraphNodesPerType : ConcurrentMap<Class<? extends Enum>,Map<? extends Enum,LockGraphNode>> to lockGraphNodesPerType : Map<Class<? extends Enum>,Map<? extends Enum,LockGraphNode>> in class com.google.common.util.concurrent.CycleDetectingLockFactory |
From |
To |
|
Change Attribute Type UNDER : ImmutableMap<String,PublicSuffixType> to UNDER : ImmutableSet<String> in class com.google.common.net.TldPatterns |
From |
To |
|
Change Attribute Type multimap : ImmutableMultimap<K,V> to multimap : ImmutableMultimap<?,V> in class com.google.common.collect.ImmutableMultimap.Values |
From |
To |
|
Change Attribute Type ALL : ImmutableRangeSet<Comparable<?>> to ALL : ImmutableRangeSet in class com.google.common.collect.ImmutableRangeSet |
From |
To |
|
Change Attribute Type typeTable : TypeTable to typeTable : ImmutableMap<TypeVariable<?>,Type> in class com.google.common.reflect.TypeResolver |
From |
To |
|
Change Attribute Type multimap : FilteredMultimap<K,V> to multimap : Multimap<K,V> in class com.google.common.collect.Multimaps.Values |
From |
To |
|
Change Attribute Type listeners : List<ListenerCallQueue<Listener>> to listeners : List<ListenerExecutorPair> in class com.google.common.util.concurrent.AbstractService |
From |
To |
|
Change Attribute Type INSTANCE : Absent<Object> to INSTANCE : Absent in class com.google.common.base.Absent |
From |
To |
|
Change Attribute Type stopwatch : SleepingStopwatch to ticker : SleepingTicker in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Change Attribute Type charsetCanonicalName : String to elements : Object[] in class com.google.common.collect.ImmutableCollection.SerializedForm |
From |
To |
|
Change Attribute Type seq : CharSequence to string : String in class com.google.common.io.CharStreams.StringCharSource |
From |
To |
|
Change Attribute Type KNOWN_TYPES : Map<MediaType,MediaType> to KNOWN_TYPES : ImmutableMap<MediaType,MediaType> in class com.google.common.net.MediaType |
From |
To |
|
Change Attribute Type EMPTY : ImmutableRangeSet<Comparable<?>> to EMPTY : ImmutableRangeSet in class com.google.common.collect.ImmutableRangeSet |
From |
To |
|
Change Attribute Type eventsToDispatch : ThreadLocal<Queue<EventWithSubscriber>> to eventsToDispatch : ThreadLocal<Queue<EventWithHandler>> in class com.google.common.eventbus.EventBus |
From |
To |
|
Rename Parameter monitor : Monitor to m : Monitor in method package AwaitHealthGuard(m Monitor) in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState.AwaitHealthGuard |
From |
To |
|
Rename Parameter elements : Iterable<E> to iterable : Iterable<E> in method public sortedCopy(iterable Iterable<E>) : List<E> in class com.google.common.collect.Ordering |
From |
To |
|
Rename Parameter newValue : V to value : V in method public setValue(value V) : V in class com.google.common.collect.Maps.FilteredEntryMap.EntrySet.iterator.next |
From |
To |
|
Rename Parameter subscriber : EventSubscriber to handler : EventHandler in method package enqueueEvent(event Object, handler EventHandler) : void in class com.google.common.eventbus.EventBus |
From |
To |
|
Rename Parameter theEntries : Entry<?,?>[] to immutableEntries : Entry<?,?>... in method package RegularImmutableMap(immutableEntries Entry<?,?>...) in class com.google.common.collect.RegularImmutableMap |
From |
To |
|
Rename Parameter inputStream : InputStream to closeable : Closeable in method public closeQuietly(closeable Closeable) : void in class com.google.common.io.Closeables |
From |
To |
|
Rename Parameter subscriber : EventSubscriber to handler : EventHandler in method package enqueueEvent(event Object, handler EventHandler) : void in class com.google.common.eventbus.AsyncEventBus |
From |
To |
|
Rename Parameter nextInValueBucket : ImmutableMapEntry<K,V> to nextInVToKBucket : BiMapEntry<K,V> in method package NonTerminalBiMapEntry(key K, value V, nextInKToVBucket BiMapEntry<K,V>, nextInVToKBucket BiMapEntry<K,V>) in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry |
From |
To |
|
Rename Parameter o : Object to obj : Object in method public remove(obj Object) : boolean in class com.google.common.collect.StandardTable.CellSet |
From |
To |
|
Rename Parameter smearedValueHash : int to valueHash : int in method package ValueEntry(key K, value V, valueHash int, nextInValueSetHashRow ValueEntry<K,V>) in class com.google.common.collect.LinkedHashMultimap.ValueEntry |
From |
To |
|
Rename Parameter elements : Iterable<E> to iterable : Iterable<E> in method public immutableSortedCopy(iterable Iterable<E>) : ImmutableList<E> in class com.google.common.collect.Ordering |
From |
To |
|
Rename Parameter stopwatch : SleepingStopwatch to ticker : SleepingTicker in method private RateLimiter(ticker SleepingTicker) in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Rename Parameter o : Object to obj : Object in method public contains(obj Object) : boolean in class com.google.common.collect.StandardTable.CellSet |
From |
To |
|
Rename Parameter charset : Charset to elements : Object[] in method package SerializedForm(elements Object[]) in class com.google.common.collect.ImmutableCollection.SerializedForm |
From |
To |
|
Rename Parameter monitor : Monitor to m : Monitor in method package StoppedGuard(m Monitor) in class com.google.common.util.concurrent.ServiceManager.ServiceManagerState.StoppedGuard |
From |
To |
|
Rename Parameter c : Collection<?> to collection : Collection<?> in method public retainAll(collection Collection<?>) : boolean in class com.google.common.collect.Maps.FilteredEntryMap.KeySet |
From |
To |
|
Rename Parameter nextInKeyBucket : ImmutableMapEntry<K,V> to nextInKToVBucket : BiMapEntry<K,V> in method package NonTerminalBiMapEntry(key K, value V, nextInKToVBucket BiMapEntry<K,V>, nextInVToKBucket BiMapEntry<K,V>) in class com.google.common.collect.RegularImmutableBiMap.NonTerminalBiMapEntry |
From |
To |
|
Rename Parameter nextInValueBucket : ValueEntry<K,V> to nextInValueSetHashRow : ValueEntry<K,V> in method package ValueEntry(key K, value V, valueHash int, nextInValueSetHashRow ValueEntry<K,V>) in class com.google.common.collect.LinkedHashMultimap.ValueEntry |
From |
To |
|
Rename Parameter stopwatch : SleepingStopwatch to ticker : SleepingTicker in method package WarmingUp(ticker SleepingTicker, warmupPeriod long, timeUnit TimeUnit) in class com.google.common.util.concurrent.RateLimiter.WarmingUp |
From |
To |
|
Rename Parameter stopwatch : SleepingStopwatch to ticker : SleepingTicker in method package create(ticker SleepingTicker, permitsPerSecond double, warmupPeriod long, timeUnit TimeUnit) : RateLimiter in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Rename Parameter byteArrayInputStream : ByteArrayInputStream to bytes : byte[] in method package ByteArrayDataInputStream(bytes byte[]) in class com.google.common.io.ByteStreams.ByteArrayDataInputStream |
From |
To |
|
Rename Parameter subscriber : EventSubscriber to handler : EventHandler in method package dispatch(event Object, handler EventHandler) : void in class com.google.common.eventbus.AsyncEventBus |
From |
To |
|
Rename Parameter stopwatch : SleepingStopwatch to ticker : SleepingTicker in method package create(ticker SleepingTicker, permitsPerSecond double) : RateLimiter in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Rename Parameter r : Runnable to runnable : Runnable in method package execute(runnable Runnable) : void in class com.google.common.util.concurrent.ServiceManager.ListenerExecutorPair |
From |
To |
|
Rename Parameter unit : TimeUnit to timeUnit : TimeUnit in method package create(ticker SleepingTicker, permitsPerSecond double, warmupPeriod long, timeUnit TimeUnit) : RateLimiter in class com.google.common.util.concurrent.RateLimiter |
From |
To |
|
Rename Parameter subscriber : EventSubscriber to handler : EventHandler in method public EventWithHandler(event Object, handler EventHandler) in class com.google.common.eventbus.EventBus.EventWithHandler |
From |
To |