A B C D E F G H I J K L M N O P Q R S T U V W Y Z 
All Classes All Packages

A

AbortingVisitor<T,​K extends Exception> - Interface in com.palantir.common.base
 
AbortingVisitors - Class in com.palantir.common.base
 
AbstractBatchingVisitable<T> - Class in com.palantir.common.base
This abstract class will implement the required methods in BatchingVisitable and will also implement the requires batchSize guarantee (only the last page is allowed to be smaller than the batch size).
AbstractBatchingVisitable() - Constructor for class com.palantir.common.base.AbstractBatchingVisitable
 
AbstractBatchingVisitable.ConsistentVisitor<T,​K extends Exception> - Class in com.palantir.common.base
 
AbstractDelegatingInvocationHandler - Class in com.palantir.common.proxy
 
AbstractDelegatingInvocationHandler() - Constructor for class com.palantir.common.proxy.AbstractDelegatingInvocationHandler
 
AbstractPagingIterable<T,​P extends BasicResultsPage<T>> - Class in com.palantir.util.paging
This class only requires two methods AbstractPagingIterable.getFirstPage() and AbstractPagingIterable.getNextPage(BasicResultsPage) to be implmented to make an iterable.
AbstractPagingIterable() - Constructor for class com.palantir.util.paging.AbstractPagingIterable
 
AbstractPagingIterable.PagingIterator<T,​P extends BasicResultsPage<T>> - Class in com.palantir.util.paging
 
AbstractPoolingContainer<T> - Class in com.palantir.common.pooling
This class will pool resources up to the passedLimit.
AbstractPoolingContainer(int) - Constructor for class com.palantir.common.pooling.AbstractPoolingContainer
Pool up to itemsToPool resources.
AggregatingVersionedMetric<T> - Class in com.palantir.util
A Gauge based off of AggregatingVersionedSupplier that exposes methods to interact with the underlying Supplier.
AggregatingVersionedMetric(AggregatingVersionedSupplier<T>) - Constructor for class com.palantir.util.AggregatingVersionedMetric
 
AggregatingVersionedSupplier<T> - Class in com.palantir.util
 
AggregatingVersionedSupplier(Function<Collection<T>, T>, long) - Constructor for class com.palantir.util.AggregatingVersionedSupplier
Creates a supplier that returns a VersionedType containing the result of applying the given aggregating function to a collection of values maintained in an internal map.
all(Predicate<? super T>) - Method in class com.palantir.common.base.BatchingVisitableView
Returns true iff every element satisfies the predicate.
all(Predicate<? super T>) - Method in class com.palantir.common.collect.IterableView
 
ALL - com.palantir.util.JMXUtils.AllowConnections
 
allAsMap(Map<T, ListenableFuture<Optional<R>>>) - Method in interface com.palantir.atlasdb.futures.FuturesCombiner
Wraps the AtlasFutures#allAsMap(Map, ExecutorService).
allAsMap(Map<T, ListenableFuture<R>>, Executor) - Static method in class com.palantir.atlasdb.futures.AtlasFutures
 
allocatedResources - Variable in class com.palantir.common.pooling.AbstractPoolingContainer
 
allOptionalsAsMap(Map<T, ListenableFuture<Optional<R>>>, Executor) - Static method in class com.palantir.atlasdb.futures.AtlasFutures
Creates a new ListenableFuture whose value is a map containing the values of all its input futures, if all succeed.
ALLOW_TO_FINISH - com.palantir.common.proxy.CancelDelegate
 
alwaysFalse() - Static method in class com.palantir.common.base.AbortingVisitors
 
alwaysTrue() - Static method in class com.palantir.common.base.AbortingVisitors
 
any(Predicate<? super T>) - Method in class com.palantir.common.base.BatchingVisitableView
Returns true iff one or more elements satisfy the predicate.
any(Predicate<? super T>) - Method in class com.palantir.common.collect.IterableView
 
ANY - com.palantir.util.io.AvailabilityRequirement
 
append(Iterable<? extends T>, T) - Static method in class com.palantir.common.collect.IterableUtils
 
append(Collection<? extends T>, T) - Static method in class com.palantir.common.collect.IterableUtils
 
appendOnClose(ClosableIterator<T>, Closeable) - Static method in class com.palantir.common.base.ClosableIterators
Run the on close after the original close method.
appendOnClose(Closeable) - Method in interface com.palantir.common.base.ClosableIterator
Run the on close after the original close method.
apply(F) - Method in interface com.palantir.common.base.FunctionCheckedException
 
applyKey(Function<F, T>) - Static method in class com.palantir.common.collect.MapEntries
 
applyKey(Predicate<K>) - Static method in class com.palantir.common.collect.MapEntries
 
applyValue(Function<F, T>) - Static method in class com.palantir.common.collect.MapEntries
 
applyValue(Predicate<V>) - Static method in class com.palantir.common.collect.MapEntries
 
assertAndLog(boolean, String) - Static method in class com.palantir.util.AssertUtils
Deprecated.
Use AssertUtils.assertAndLog(Logger, boolean, String) instead. This will make sure log events go to your logger instead of a hard-to-filter default. (com.palantir.util.AssertUtils)
assertAndLog(boolean, String, Object...) - Static method in class com.palantir.util.AssertUtils
Deprecated.
Use AssertUtils.assertAndLog(Logger, boolean, String, Object...) instead. This will make sure log events go to your logger instead of a hard-to-filter default. (com.palantir.util.AssertUtils)
assertAndLog(SafeLogger, boolean, String) - Static method in class com.palantir.util.AssertUtils
 
assertAndLog(SafeLogger, boolean, String, Arg<?>...) - Static method in class com.palantir.util.AssertUtils
 
assertAndLog(Logger, boolean, String) - Static method in class com.palantir.util.AssertUtils
 
assertAndLog(Logger, boolean, String, Object...) - Static method in class com.palantir.util.AssertUtils
 
assertAndLogWithException(boolean, String, Throwable) - Static method in class com.palantir.util.AssertUtils
Deprecated.
Use AssertUtils.assertAndLogWithException(Logger, boolean, String, Throwable) instead. This will make sure log events go to your logger instead of a hard-to-filter default. (com.palantir.util.AssertUtils)
assertAndLogWithException(boolean, String, Throwable, Object...) - Static method in class com.palantir.util.AssertUtils
Deprecated.
Use AssertUtils.assertAndLogWithException(Logger, boolean, String, Throwable, Object...) instead. This will make sure log events go to your logger instead of a hard-to-filter default. (com.palantir.util.AssertUtils)
assertAndLogWithException(SafeLogger, boolean, String, Throwable) - Static method in class com.palantir.util.AssertUtils
 
assertAndLogWithException(SafeLogger, boolean, String, Throwable, Arg<?>...) - Static method in class com.palantir.util.AssertUtils
 
assertAndLogWithException(Logger, boolean, String, Throwable) - Static method in class com.palantir.util.AssertUtils
 
assertAndLogWithException(Logger, boolean, String, Throwable, Object...) - Static method in class com.palantir.util.AssertUtils
 
assertListElementsUnique(List<T>) - Static method in class com.palantir.util.AssertUtils
 
AssertUtils - Class in com.palantir.util
 
AssertUtils() - Constructor for class com.palantir.util.AssertUtils
 
AsyncInitializationState - Class in com.palantir.async.initializer
 
AsyncInitializationState() - Constructor for class com.palantir.async.initializer.AsyncInitializationState
 
AsyncInitializationState.State - Enum in com.palantir.async.initializer
 
AsyncInitializer - Class in com.palantir.async.initializer
Implements basic infrastructure to allow an object to be asynchronously initialized.
AsyncInitializer() - Constructor for class com.palantir.async.initializer.AsyncInitializer
 
AtlasDbDependencyException - Exception in com.palantir.common.exception
 
AtlasDbDependencyException(String) - Constructor for exception com.palantir.common.exception.AtlasDbDependencyException
 
AtlasDbDependencyException(String, Throwable) - Constructor for exception com.palantir.common.exception.AtlasDbDependencyException
 
AtlasDbDependencyException(Throwable) - Constructor for exception com.palantir.common.exception.AtlasDbDependencyException
 
AtlasFutures - Class in com.palantir.atlasdb.futures
 
AvailabilityRequirement - Enum in com.palantir.util.io
 
available() - Method in class com.palantir.common.compression.BufferedDelegateInputStream
 

B

BasicResultsPage<T> - Interface in com.palantir.util.paging
Provides a minimal paging interface.
batchAccept(int, AbortingVisitor<? super List<T>, K>) - Method in class com.palantir.common.base.AbstractBatchingVisitable
 
batchAccept(int, AbortingVisitor<? super List<T>, K>) - Method in interface com.palantir.common.base.BatchingVisitable
This method should be used to visit elements in batches until the visitor returns false or there are no batches left to visit.
batchAccept(int, AbortingVisitor<? super List<T>, K>) - Method in class com.palantir.common.base.BatchingVisitableView
 
batchAccept(int, AbortingVisitor<? super List<T>, K>) - Method in class com.palantir.common.base.PrefetchingBatchingVisitable
 
batchAcceptSizeHint(int, AbstractBatchingVisitable.ConsistentVisitor<T, K>) - Method in class com.palantir.common.base.AbstractBatchingVisitable
The batch size passed to this method is purely a hint.
batchAcceptSizeHint(int, AbstractBatchingVisitable.ConsistentVisitor<T, K>) - Method in class com.palantir.common.base.BatchingVisitableFromIterable
 
batching(AbortingVisitor<? super T, ? extends K>) - Static method in class com.palantir.common.base.AbortingVisitors
 
BatchingVisitable<T> - Interface in com.palantir.common.base
 
BatchingVisitableFromIterable<T> - Class in com.palantir.common.base
 
BatchingVisitableFromIterable(Iterable<? extends T>) - Constructor for class com.palantir.common.base.BatchingVisitableFromIterable
 
BatchingVisitables - Class in com.palantir.common.base
 
BatchingVisitableView<T> - Class in com.palantir.common.base
A wrapper for BatchingVisitable which adds support for common operations.
begin(String) - Method in interface com.palantir.util.jmx.OperationTimer
 
begin(String) - Method in class com.palantir.util.timer.LoggingOperationTimer
 
BlockingWorkerPool<T> - Class in com.palantir.common.concurrent
 
BlockingWorkerPool(ExecutorService, int) - Constructor for class com.palantir.common.concurrent.BlockingWorkerPool
Construct a BlockingWorkerPool.
blockUntilSafeToShutdown() - Method in class com.palantir.async.initializer.Callback
Send a shutdown signal and block until potential cleanup has finished running.
buffer - Variable in class com.palantir.common.compression.BufferedDelegateInputStream
 
BUFFER_START - Static variable in class com.palantir.common.compression.BufferedDelegateInputStream
 
BufferedDelegateInputStream - Class in com.palantir.common.compression
InputStream that wraps a delegate InputStream, buffering reads to the delegate.
BufferedDelegateInputStream(InputStream, int) - Constructor for class com.palantir.common.compression.BufferedDelegateInputStream
 
ByteArrayIOStream - Class in com.palantir.util
Simple io stream designed for passing bytes from an output stream to an input stream (or multiple input streams).
ByteArrayIOStream() - Constructor for class com.palantir.util.ByteArrayIOStream
 
ByteArrayIOStream(int) - Constructor for class com.palantir.util.ByteArrayIOStream
 
BYTES_HYDRATOR - Static variable in enum com.palantir.util.PersistableBoolean
returns FALSE iff the provided byte array is a single zero byte.

C

CachedComposedSupplier<T,​R> - Class in com.palantir.util
A version of composed supplier that caches the result of applying the function to the value supplied by the underlying supplier of VersionedType.
CachedComposedSupplier(Function<T, R>, Supplier<VersionedType<T>>) - Constructor for class com.palantir.util.CachedComposedSupplier
 
CachedComposedSupplier(Function<T, R>, Supplier<VersionedType<T>>, long, Clock) - Constructor for class com.palantir.util.CachedComposedSupplier
 
cacheEntries - Variable in class com.palantir.util.SoftCache
 
CacheEntry(Reference<V>) - Constructor for class com.palantir.util.SoftCache.CacheEntry
 
CacheStats - Class in com.palantir.util
 
CacheStats(MBeanCache<?, ?>) - Constructor for class com.palantir.util.CacheStats
 
CacheStatsMBean - Interface in com.palantir.util
 
calculateRequired(int) - Method in enum com.palantir.util.io.AvailabilityRequirement
 
call() - Method in class com.palantir.common.concurrent.InterruptibleFuture
 
Callback<R> - Class in com.palantir.async.initializer
 
Callback() - Constructor for class com.palantir.async.initializer.Callback
 
Callback.CallChain<T> - Class in com.palantir.async.initializer
A CallChain executes a list of callbacks in sequence.
CallbackInitializable<R> - Interface in com.palantir.async.initializer
 
CallChain(Callback<T>...) - Constructor for class com.palantir.async.initializer.Callback.CallChain
 
CallChain(List<Callback<T>>) - Constructor for class com.palantir.async.initializer.Callback.CallChain
 
cancel(boolean) - Method in class com.palantir.common.concurrent.InterruptibleFuture
 
CANCEL - com.palantir.common.proxy.CancelDelegate
 
CancelDelegate - Enum in com.palantir.common.proxy
Should we cancel a delegate thread, or allow it to finish on its own?
cancelInitialization(Runnable) - Method in class com.palantir.async.initializer.AsyncInitializer
Cancels future initializations and registers a callback to be called if the initialization is happening and succeeds.
CANCELLED - com.palantir.async.initializer.AsyncInitializationState.State
 
canonicalize(Map<K, V>) - Method in class com.palantir.util.SoftCache
This convenience method takes a map of items returned from the backing store and replaces references loaded from the backing store with items in the cache.
chain(T, Throwable) - Static method in class com.palantir.common.base.Throwables
Simply call throwable.initCause(cause) and return throwable.
CheckedRejectedExecutionException - Exception in com.palantir.common.concurrent
Similar to RejectedExecutionException, but requires explicit handling.
CheckedRejectedExecutionException(String) - Constructor for exception com.palantir.common.concurrent.CheckedRejectedExecutionException
 
CheckedRejectedExecutionException(Throwable) - Constructor for exception com.palantir.common.concurrent.CheckedRejectedExecutionException
 
CheckedRejectionExecutorService - Class in com.palantir.common.concurrent
A CheckedRejectionExecutorService is an executor where submitters of tasks MUST be prepared to handle execution being rejected - and we thus throw a checked exception when submitting tasks.
CheckedRejectionExecutorService(ExecutorService) - Constructor for class com.palantir.common.concurrent.CheckedRejectionExecutorService
 
checkInitialized() - Method in class com.palantir.async.initializer.AsyncInitializer
 
chooseRandomElements(Iterator<? extends T>, int) - Static method in class com.palantir.common.collect.IteratorUtils
 
cleanup() - Method in class com.palantir.util.SoftCache
Iterates through the cache and cleans up any cache references that have been collected by the garbage collector.
cleanup(R, Throwable) - Method in class com.palantir.async.initializer.Callback
Cleanup to be done if init() throws, before init() can be attempted again.
cleanup(R, Throwable) - Method in class com.palantir.async.initializer.LambdaCallback
 
cleanup(T, Throwable) - Method in class com.palantir.async.initializer.Callback.CallChain
 
cleanupForDiscard(T) - Method in class com.palantir.common.pooling.AbstractPoolingContainer
This will be called after a resource is done being used but the pool is full and it will be discarded
cleanupForReturnToPool(T) - Method in class com.palantir.common.pooling.AbstractPoolingContainer
This will be called after a resource is done being used and will be returned to the pool so it maybe used again.
cleanUpOnInitFailure() - Method in class com.palantir.async.initializer.AsyncInitializer
Override this method if there's anything to be cleaned up on initialization failure.
clear() - Method in class com.palantir.util.MBeanCache
Clears all entries from the cache.
clear() - Method in interface com.palantir.util.NonDistributedCache
 
clear() - Method in class com.palantir.util.SoftCache.CacheEntry
 
clear() - Method in class com.palantir.util.SoftCache
Clears all entries from the cache.
clearCacheAndStats() - Method in class com.palantir.util.CacheStats
 
clearCacheAndStats() - Method in interface com.palantir.util.CacheStatsMBean
 
Clock - Interface in com.palantir.common.time
 
ClosableIterator<T> - Interface in com.palantir.common.base
 
ClosableIterators - Class in com.palantir.common.base
 
close() - Method in interface com.palantir.atlasdb.futures.FuturesCombiner
 
close() - Method in interface com.palantir.common.base.ClosableIterator
 
close() - Method in class com.palantir.common.base.ForwardingClosableIterator
 
close() - Method in class com.palantir.common.compression.BufferedDelegateInputStream
 
close() - Method in class com.palantir.common.compression.LZ4CompressingInputStream
 
close() - Method in class com.palantir.common.io.ConcatenatedInputStream
 
close() - Method in class com.palantir.util.file.DeleteOnCloseFileInputStream
 
close() - Method in class com.palantir.util.SafeShutdownRunner
 
CoalescingSupplier<T> - Class in com.palantir.common.concurrent
A supplier that coalesces computation requests, such that only one computation is ever running at a time, and concurrent requests will result in a single computation.
CoalescingSupplier(Supplier<T>) - Constructor for class com.palantir.common.concurrent.CoalescingSupplier
 
collectStatsLoadTimeForCacheKey(long) - Method in class com.palantir.util.MBeanCache
 
collectStatsLoadTimeForMiss(long) - Method in class com.palantir.util.MBeanCache
 
com.palantir.async.initializer - package com.palantir.async.initializer
 
com.palantir.atlasdb.futures - package com.palantir.atlasdb.futures
 
com.palantir.common.annotations - package com.palantir.common.annotations
 
com.palantir.common.base - package com.palantir.common.base
 
com.palantir.common.collect - package com.palantir.common.collect
 
com.palantir.common.compression - package com.palantir.common.compression
 
com.palantir.common.concurrent - package com.palantir.common.concurrent
 
com.palantir.common.exception - package com.palantir.common.exception
 
com.palantir.common.io - package com.palantir.common.io
 
com.palantir.common.persist - package com.palantir.common.persist
 
com.palantir.common.pooling - package com.palantir.common.pooling
 
com.palantir.common.proxy - package com.palantir.common.proxy
 
com.palantir.common.random - package com.palantir.common.random
 
com.palantir.common.remoting - package com.palantir.common.remoting
 
com.palantir.common.time - package com.palantir.common.time
 
com.palantir.common.visitor - package com.palantir.common.visitor
 
com.palantir.exception - package com.palantir.exception
 
com.palantir.leader - package com.palantir.leader
 
com.palantir.nexus.db - package com.palantir.nexus.db
 
com.palantir.util - package com.palantir.util
 
com.palantir.util.crypto - package com.palantir.util.crypto
 
com.palantir.util.debug - package com.palantir.util.debug
 
com.palantir.util.file - package com.palantir.util.file
 
com.palantir.util.io - package com.palantir.util.io
 
com.palantir.util.jmx - package com.palantir.util.jmx
 
com.palantir.util.paging - package com.palantir.util.paging
 
com.palantir.util.result - package com.palantir.util.result
 
com.palantir.util.timer - package com.palantir.util.timer
 
compareLhSide() - Static method in class com.palantir.util.Pair
Returns a Comparator for the left-hand side object of the Pair.
compareLhSide(Comparator<? super T>) - Static method in class com.palantir.util.Pair
Returns a Comparator for the left-hand side object of the Pair.
compareRhSide() - Static method in class com.palantir.util.Pair
Returns a Comparator for the right-hand side object of the Pair.
compareRhSide(Comparator<? super W>) - Static method in class com.palantir.util.Pair
Returns a Comparator for the right-hand side object of the Pair.
compareTo(NanoTime) - Method in class com.palantir.common.time.NanoTime
 
compareTo(Sha256Hash) - Method in class com.palantir.util.crypto.Sha256Hash
 
compress(InputStream) - Static method in class com.palantir.common.compression.GzipCompressingInputStream
Wraps a stream with GZIP compression using default compression level and reasonable default buffer size.
compress(InputStream) - Method in enum com.palantir.common.compression.StreamCompression
 
compress(InputStream, short, int) - Static method in class com.palantir.common.compression.GzipCompressingInputStream
Wraps a stream with GZIP compression.
computeHash(byte[]) - Static method in class com.palantir.util.crypto.Sha256Hash
Computes the SHA-256 hash for the given array of bytes.
computeNext() - Method in class com.palantir.util.paging.AbstractPagingIterable.PagingIterator
 
concat(BatchingVisitable<? extends T>...) - Static method in class com.palantir.common.base.BatchingVisitables
 
concat(BatchingVisitable<? extends T>...) - Method in class com.palantir.common.base.BatchingVisitableView
 
concat(Iterable<? extends BatchingVisitable<? extends T>>) - Static method in class com.palantir.common.base.BatchingVisitables
 
concat(Iterable<? extends T>) - Method in class com.palantir.common.collect.IterableView
 
concat(Iterable<? extends T>...) - Method in class com.palantir.common.collect.IterableView
 
concat(Iterable<? extends T>, Iterable<? extends T>) - Method in class com.palantir.common.collect.IterableView
 
ConcatenatedInputStream - Class in com.palantir.common.io
 
ConcatenatedInputStream(Iterable<InputStream>) - Constructor for class com.palantir.common.io.ConcatenatedInputStream
 
consumingIterable() - Method in class com.palantir.common.collect.IterableView
 
contains(Object) - Method in class com.palantir.common.collect.IterableView
 
containsKey(K) - Method in interface com.palantir.util.NonDistributedCache
 
containsKey(K) - Method in class com.palantir.util.SoftCache
 
containsValue(V) - Method in class com.palantir.util.SoftCache
 
copy(T) - Static method in class com.palantir.common.proxy.SerializingUtils
 
copy(T, ObjectInputStreamFactory) - Static method in class com.palantir.common.proxy.SerializingUtils
 
copyInto(S) - Method in class com.palantir.common.base.BatchingVisitableView
Copies the elements in this visitable into an existing collection.
copyInto(S) - Method in class com.palantir.common.collect.IterableView
Copies the current contents of this set view into an existing collection.
copyToList(BatchingVisitable<T>) - Static method in class com.palantir.common.base.BatchingVisitables
 
count() - Method in class com.palantir.common.base.BatchingVisitableView
 
count(BatchingVisitable<?>) - Static method in class com.palantir.common.base.BatchingVisitables
 
count(BatchingVisitable<?>, int) - Static method in class com.palantir.common.base.BatchingVisitables
 
create() - Static method in exception com.palantir.exception.PalantirSqlException
 
create() - Static method in class com.palantir.util.Mutable
 
create(boolean) - Static method in class com.palantir.util.MutuallyExclusiveSetLock
 
create(SafeLogger) - Static method in class com.palantir.util.timer.LoggingOperationTimer
 
create(InputStream, String) - Method in interface com.palantir.util.ObjectInputStreamFactory
 
create(Class<?>) - Static method in class com.palantir.util.timer.LoggingOperationTimer
 
create(Class<T>, Supplier<T>, Duration, Predicate<Throwable>) - Static method in class com.palantir.common.proxy.ReplaceIfExceptionMatchingProxy
 
create(Iterable<? extends T>) - Static method in class com.palantir.common.base.BatchingVisitableFromIterable
 
create(Iterable<T>) - Static method in class com.palantir.util.paging.SimpleResultsPage
 
create(Iterable<T>, boolean) - Static method in class com.palantir.util.paging.SimpleResultsPage
 
create(String) - Static method in exception com.palantir.exception.PalantirSqlException
 
create(String) - Static method in class com.palantir.util.timer.LoggingOperationTimer
 
create(SQLException) - Static method in exception com.palantir.exception.PalantirSqlException
 
create(Duration) - Static method in class com.palantir.util.TimedRunner
 
create(Callable<T>, Runnable) - Static method in interface com.palantir.util.TimedRunner.TaskContext
 
create(Iterator<? extends T>) - Static method in class com.palantir.common.base.BatchingVisitableFromIterable
This creates a one time use visitable.
create(Map<? extends K, ExecutorService>) - Static method in class com.palantir.common.concurrent.MultiplexingCompletionService
 
create(TOKEN, Iterable<T>) - Static method in class com.palantir.util.paging.SimpleTokenBackedResultsPage
 
create(TOKEN, Iterable<T>, boolean) - Static method in class com.palantir.util.paging.SimpleTokenBackedResultsPage
 
create(V, W) - Static method in class com.palantir.util.Pair
Returns a new Pair instance with the given left-side and right-side objects.
createCache(int) - Method in class com.palantir.util.SoftCache
This method should be over-ridden by subclasses to change the underlying cache implementation and implement features like LRU caches...
createConstantValueMap(Iterable<K>, V) - Static method in class com.palantir.common.collect.Maps2
 
createConstantValueMap(Set<K>, V) - Static method in class com.palantir.common.collect.Maps2
 
createForChaining() - Static method in exception com.palantir.exception.PalantirSqlException
 
createForChaining(String) - Static method in exception com.palantir.exception.PalantirSqlException
 
createForTests(long) - Static method in class com.palantir.common.time.NanoTime
 
createFrom(InputStream) - Static method in class com.palantir.util.crypto.Sha256Hash
This method will read all the bytes in the stream and digest them.
createFrom(MessageDigest) - Static method in class com.palantir.util.crypto.Sha256Hash
 
createFromCheckedExecutors(Map<? extends K, CheckedRejectionExecutorService>) - Static method in class com.palantir.common.concurrent.MultiplexingCompletionService
 
createNewPooledResource() - Method in class com.palantir.common.pooling.AbstractPoolingContainer
This should create a new resource.
createRunnable(Runnable, Runnable) - Static method in interface com.palantir.util.TimedRunner.TaskContext
 
createTempDirectory(String, String) - Static method in class com.palantir.util.file.TempFileUtils
 
createTempFile(String, String) - Static method in class com.palantir.util.file.TempFileUtils
 
createTempFile(String, String, File) - Static method in class com.palantir.util.file.TempFileUtils
 
createWithCachedThreadpool(Duration) - Static method in class com.palantir.util.SafeShutdownRunner
 
createWithComparator(boolean, Comparator<? super T>) - Static method in class com.palantir.util.MutuallyExclusiveSetLock
Constructs a new MutuallyExclusiveSetLock that will lock the objects in the order determined by comparator.
cycle() - Method in class com.palantir.common.collect.IterableView
 

D

decompress(InputStream) - Method in enum com.palantir.common.compression.StreamCompression
 
DEFAULT_BATCH_SIZE - Static variable in class com.palantir.common.base.BatchingVisitables
 
DelayProxy - Class in com.palantir.common.proxy
 
DelayProxy(Object, Supplier<Long>) - Constructor for class com.palantir.common.proxy.DelayProxy
 
delegate - Variable in class com.palantir.common.compression.BufferedDelegateInputStream
 
delegate() - Method in class com.palantir.common.base.BatchingVisitableView
 
delegate() - Method in class com.palantir.common.base.ForwardingClosableIterator
 
delegate() - Method in class com.palantir.common.collect.IterableView
 
delegate() - Method in class com.palantir.common.pooling.ForwardingPoolingContainer
 
DelegatingInvocationHandler - Interface in com.palantir.common.proxy
 
DeleteOnCloseFileInputStream - Class in com.palantir.util.file
 
DeleteOnCloseFileInputStream(File) - Constructor for class com.palantir.util.file.DeleteOnCloseFileInputStream
 
deSerializeFromBase64String(String) - Static method in class com.palantir.util.crypto.Sha256Hash
 
deSerializeFromHexString(String) - Static method in class com.palantir.util.crypto.Sha256Hash
 
discardCurrentPool() - Method in class com.palantir.common.pooling.AbstractPoolingContainer
This method is used when we still want to continue to pool, but we think that the current pooled resources are no longer good to use.
DistributedCacheMgrCache<K,​V> - Interface in com.palantir.util
This interface exists because many cache calls don't make sense in a distributed sense.
DONE - com.palantir.async.initializer.AsyncInitializationState.State
 
drainAllPages() - Method in class com.palantir.util.paging.PageDrainer
 

E

EMPTY - Static variable in class com.palantir.util.crypto.Sha256Hash
The hash of an empty byte array, which can be used as a sentinel value.
emptyBatchingVisitable() - Static method in class com.palantir.common.base.BatchingVisitables
 
emptyImmutableClosableIterator() - Static method in class com.palantir.common.base.ClosableIterators
 
emptyPage() - Static method in class com.palantir.util.paging.SimpleResultsPage
Constructs an empty results page.
EmptyQueue<E> - Class in com.palantir.common.collect
This queue is empty and will neither return nor accept any elements
emptyVisitor() - Static method in class com.palantir.common.base.Visitors
Return a visitor that does nothing.
end() - Method in interface com.palantir.util.jmx.OperationTimer.TimingState
 
ensureDirectoryExists(String) - Static method in class com.palantir.util.file.TempFileUtils
Ensures that the directory specified by the path exists
ensureFileExists(File) - Static method in class com.palantir.util.file.TempFileUtils
Ensures that the file exists
ensureTempDirectoryExists() - Static method in class com.palantir.util.file.TempFileUtils
Ensures that the tmp directory in the java.io.tmpdir system property exists
entryTransformerFromFun(Function<Map.Entry<K, V1>, V2>) - Static method in class com.palantir.common.collect.MapEntries
 
equals(Object) - Method in class com.palantir.util.crypto.Sha256Hash
 
equals(Object) - Method in class com.palantir.util.Mutable
Returns true if this Mutable is equal to the given object.
equals(Object) - Method in class com.palantir.util.paging.SimpleResultsPage
 
equals(Object) - Method in class com.palantir.util.paging.SimpleTokenBackedResultsPage
 
equals(Object) - Method in class com.palantir.util.Pair
Returns true if this Pair is equal to the given object.
err(E) - Static method in interface com.palantir.util.result.Result
 
execute(Runnable) - Method in class com.palantir.common.concurrent.CheckedRejectionExecutorService
 
ExperimentRunningProxy<T> - Class in com.palantir.common.proxy
 

F

FALSE - com.palantir.util.PersistableBoolean
 
filter(Predicate<? super T>) - Method in class com.palantir.common.base.BatchingVisitableView
 
filter(Predicate<? super T>) - Method in class com.palantir.common.collect.IterableView
 
filter(BatchingVisitable<T>, Predicate<? super T>) - Static method in class com.palantir.common.base.BatchingVisitables
 
filter(Class<? extends U>) - Method in class com.palantir.common.base.BatchingVisitableView
 
filter(Class<? extends U>) - Method in class com.palantir.common.collect.IterableView
 
filter(Collection<K>) - Method in class com.palantir.util.SoftCache
This convenience method filters a request by removing all items in the request which are in the cache and returning the corresponding values.
filterAndVisit(Iterator<? extends T>, Predicate<? super T>, Visitor<? super T>, Visitor<? super T>) - Static method in class com.palantir.common.collect.IteratorUtils
Returns the elements of unfiltered that satisfy a predicate, calling passVisitor.visit() on all that satisfy the predicate and failVisitor.visit() on all that do not.
filterBatch(AbortingVisitor<? super List<T>, K>, Predicate<? super T>) - Static method in class com.palantir.common.base.AbortingVisitors
find(Predicate<? super T>) - Method in class com.palantir.common.collect.IterableView
 
find(Predicate<? super T>, T) - Method in class com.palantir.common.base.BatchingVisitableView
 
flatMap(Function<T, Collection<U>>) - Method in interface com.palantir.common.base.ClosableIterator
 
flatten(int, BatchingVisitable<? extends BatchingVisitable<? extends T>>) - Static method in class com.palantir.common.base.BatchingVisitables
 
forEach(int, Visitor<T>) - Method in class com.palantir.common.base.BatchingVisitableView
 
forEach(Visitor<T>) - Method in class com.palantir.common.base.BatchingVisitableView
 
ForwardingClosableIterator<T> - Class in com.palantir.common.base
 
ForwardingClosableIterator() - Constructor for class com.palantir.common.base.ForwardingClosableIterator
 
ForwardingPoolingContainer<T> - Class in com.palantir.common.pooling
 
ForwardingPoolingContainer() - Constructor for class com.palantir.common.pooling.ForwardingPoolingContainer
 
frequency(Object) - Method in class com.palantir.common.collect.IterableView
 
fromEntries(Iterable<? extends Map.Entry<K, V>>) - Static method in class com.palantir.common.collect.Maps2
 
FunctionCheckedException<F,​T,​K extends Exception> - Interface in com.palantir.common.base
 
funFromEntryTransformer(Maps.EntryTransformer<K, V1, V2>) - Static method in class com.palantir.common.collect.MapEntries
 
futuresCombiner(ExecutorService) - Static method in class com.palantir.atlasdb.futures.AtlasFutures
Constructs a FuturesCombiner implementation which takes ownership of the executorService and calls ExecutorService.shutdown() when close is called on it.
FuturesCombiner - Interface in com.palantir.atlasdb.futures
Interface which provides a wrapping over static methods in AtlasFutures which need an ExecutorService.

G

get() - Method in class com.palantir.common.concurrent.CoalescingSupplier
 
get() - Method in class com.palantir.common.concurrent.InterruptibleFuture
get() - Method in class com.palantir.util.AggregatingVersionedSupplier
 
get() - Method in class com.palantir.util.CachedComposedSupplier
 
get() - Method in class com.palantir.util.Mutable
Returns the value enclosed by this Mutable.
get(int) - Method in class com.palantir.common.collect.IterableView
 
get(int, T) - Method in class com.palantir.common.collect.IterableView
 
get(long, TimeUnit) - Method in class com.palantir.common.concurrent.InterruptibleFuture
get(K) - Method in interface com.palantir.util.DistributedCacheMgrCache
The only thing this call ensures is that it will either return null or some value that was DistributedCacheMgrCache.put(Object, Object) for this key.
get(K) - Method in class com.palantir.util.SoftCache
Gets an object from the cache.
getAllocatedResources() - Method in class com.palantir.common.pooling.AbstractPoolingContainer
 
getArgs() - Method in exception com.palantir.common.remoting.ServiceNotAvailableException
 
getArgs() - Method in exception com.palantir.exception.NotInitializedException
 
getArgs() - Method in exception com.palantir.exception.SafeSSLPeerUnverifiedException
 
getAsync() - Method in class com.palantir.common.concurrent.CoalescingSupplier
 
getBatchAllowDuplicates(long, int) - Method in interface com.palantir.common.base.OrderedSublistProvider
Gets a sorted list of the next maxNumResults T's identified by at least startID.
getBytes() - Method in class com.palantir.util.crypto.Sha256Hash
 
getCacheClass() - Method in class com.palantir.util.CacheStats
 
getCacheClass() - Method in interface com.palantir.util.CacheStatsMBean
 
getCacheHitPercentage() - Method in class com.palantir.util.CacheStats
 
getCacheHitPercentage() - Method in interface com.palantir.util.CacheStatsMBean
 
getDebuggingException() - Static method in class com.palantir.util.AssertUtils
 
getDelegate() - Method in class com.palantir.common.proxy.DelayProxy
 
getDelegate() - Method in interface com.palantir.common.proxy.DelegatingInvocationHandler
 
getDelegate() - Method in class com.palantir.common.proxy.InterruptibleProxy
 
getDelegate() - Method in class com.palantir.common.proxy.TimingProxy
 
getDelegate() - Method in class com.palantir.util.timer.LoggingOperationTimer
 
getDone(ListenableFuture<R>) - Static method in class com.palantir.atlasdb.futures.AtlasFutures
 
getFile() - Method in class com.palantir.util.file.DeleteOnCloseFileInputStream
 
getFirst() - Method in class com.palantir.common.base.BatchingVisitableView
Gets the first element in the visitable.
getFirst() - Method in class com.palantir.common.collect.IterableView
 
getFirst(BatchingVisitable<T>) - Static method in class com.palantir.common.base.BatchingVisitables
Returns the first element or null if the visitable is empty
getFirst(BatchingVisitable<T>, T) - Static method in class com.palantir.common.base.BatchingVisitables
 
getFirst(Iterable<T>) - Static method in class com.palantir.common.collect.IterableUtils
Get first element or null if the iterable is empty.
getFirst(Iterator<? extends T>) - Static method in class com.palantir.common.collect.IteratorUtils
Get first element or null if the iterator is empty.
getFirst(Iterator<? extends T>, T) - Static method in class com.palantir.common.collect.IteratorUtils
 
getFirst(T) - Method in class com.palantir.common.base.BatchingVisitableView
Gets the first element in the visitable.
getFirstPage() - Method in class com.palantir.util.paging.AbstractPagingIterable
 
getFirstPage() - Method in interface com.palantir.util.paging.PageGetter
 
getFirstPage(int) - Method in class com.palantir.common.base.BatchingVisitableView
 
getFirstPage(BatchingVisitable<T>, int) - Static method in class com.palantir.common.base.BatchingVisitables
 
getFirstPage(BatchingVisitable<T>, int, Function<T, TOKEN>) - Static method in class com.palantir.common.base.BatchingVisitables
 
getForcedGcCount() - Method in class com.palantir.util.CacheStats
 
getForcedGcCount() - Method in interface com.palantir.util.CacheStatsMBean
 
getHitCount() - Method in class com.palantir.util.CacheStats
 
getHitCount() - Method in interface com.palantir.util.CacheStatsMBean
 
getHydrator(Class<T>) - Static method in class com.palantir.common.persist.Persistables
 
getInitializingClassName() - Method in class com.palantir.async.initializer.AsyncInitializer
This method should contain the name of the initializing class.
getInputStream() - Method in class com.palantir.util.ByteArrayIOStream
Returns an input stream that reads from the bytes in this stream.
getInstanceBeanProxies(Class<T>) - Static method in class com.palantir.util.JMXUtils
Returns proxy interfaces to all beans registered to the server implementing the class mbeanClazz.
getInverseHits() - Method in class com.palantir.util.CacheStats
 
getInverseHits() - Method in interface com.palantir.util.CacheStatsMBean
 
getInverseMisses() - Method in class com.palantir.util.CacheStats
 
getInverseMisses() - Method in interface com.palantir.util.CacheStatsMBean
 
getKey() - Method in interface com.palantir.util.KeyedReference
 
getKey() - Method in class com.palantir.util.KeyedSoftReference
 
getKey() - Method in class com.palantir.util.KeyedWeakReference
 
getKeyFunction() - Static method in class com.palantir.common.collect.MapEntries
 
getLast() - Method in class com.palantir.common.base.BatchingVisitableView
Gets the last element in the visitable.
getLast() - Method in class com.palantir.common.collect.IterableView
 
getLast(BatchingVisitable<T>) - Static method in class com.palantir.common.base.BatchingVisitables
 
getLast(BatchingVisitable<T>, T) - Static method in class com.palantir.common.base.BatchingVisitables
 
getLast(T) - Method in class com.palantir.common.base.BatchingVisitableView
Gets the last element in the visitable.
getLast(T) - Method in class com.palantir.common.collect.IterableView
 
getLastFullPageProcessed() - Method in class com.palantir.util.paging.AbstractPagingIterable.PagingIterator
As this iterator pages through all the results this call will get you the token you can use to get more data at a later date.
getLastValueForKey(Integer) - Method in class com.palantir.util.AggregatingVersionedMetric
 
getLastValueForKey(Integer) - Method in class com.palantir.util.AggregatingVersionedSupplier
 
getLeftFunc() - Static method in class com.palantir.util.Pair
 
getLhSide() - Method in class com.palantir.util.Pair
Returns the left-hand side, or first, object of the pair.
getLoadTimeForCacheKey() - Method in class com.palantir.util.CacheStats
 
getLoadTimeForCacheKey() - Method in interface com.palantir.util.CacheStatsMBean
 
getLoadTimeFromMisses() - Method in class com.palantir.util.CacheStats
 
getLoadTimeFromMisses() - Method in interface com.palantir.util.CacheStatsMBean
 
getLogMessage() - Method in exception com.palantir.common.remoting.ServiceNotAvailableException
 
getLogMessage() - Method in exception com.palantir.exception.NotInitializedException
 
getLogMessage() - Method in exception com.palantir.exception.SafeSSLPeerUnverifiedException
 
getMagicPrefix() - Static method in class com.palantir.common.compression.GzipCompressingInputStream
 
getMax(Ordering<? super T>, T) - Method in class com.palantir.common.base.BatchingVisitableView
This will return the first maximal element in the visitable.
getMax(BatchingVisitable<T>) - Static method in class com.palantir.common.base.BatchingVisitables
This method will throw if there are nulls in the visitable.
getMax(BatchingVisitable<T>, Ordering<? super T>, T) - Static method in class com.palantir.common.base.BatchingVisitables
This will return the first maximal element in the visitable.
getMaxCacheSize() - Method in class com.palantir.util.CacheStats
 
getMaxCacheSize() - Method in interface com.palantir.util.CacheStatsMBean
 
getMaxCacheSize() - Method in class com.palantir.util.MBeanCache
 
getMaxCacheSize() - Method in class com.palantir.util.SoftCache
 
getMaxPoolSize() - Method in class com.palantir.common.pooling.AbstractPoolingContainer
 
getMessageDigest() - Static method in class com.palantir.util.crypto.Sha256Hash
Returns a MessageDigest for computing SHA-256 hashes.
getMin(Ordering<? super T>, T) - Method in class com.palantir.common.base.BatchingVisitableView
This will return the first maximal element in the visitable.
getMin(BatchingVisitable<T>) - Static method in class com.palantir.common.base.BatchingVisitables
This method will throw if there are nulls in the visitable.
getMin(BatchingVisitable<T>, Ordering<? super T>, T) - Static method in class com.palantir.common.base.BatchingVisitables
This will return the first maximal element in the visitable.
getMissCount() - Method in class com.palantir.util.CacheStats
 
getMissCount() - Method in interface com.palantir.util.CacheStatsMBean
 
getName() - Method in class com.palantir.util.CacheStats
 
getName() - Method in interface com.palantir.util.CacheStatsMBean
 
getName() - Method in class com.palantir.util.MBeanCache
 
getNextPage(List<T>) - Method in interface com.palantir.util.paging.PageGetter
 
getNextPage(P) - Method in class com.palantir.util.paging.AbstractPagingIterable
 
getOnlyElement() - Method in class com.palantir.common.collect.IterableView
 
getOnlyElement(T) - Method in class com.palantir.common.collect.IterableView
 
getOrderedVisitableUsingSublists(OrderedSublistProvider<Long>, long) - Static method in class com.palantir.common.base.BatchingVisitables
 
getOrderedVisitableUsingSublists(OrderedSublistProvider<T>, long, Function<T, Long>) - Static method in class com.palantir.common.base.BatchingVisitables
 
getPageSize() - Method in interface com.palantir.util.paging.PageGetter
 
getPutCount() - Method in class com.palantir.util.CacheStats
 
getPutCount() - Method in interface com.palantir.util.CacheStatsMBean
 
getResource() - Method in class com.palantir.common.pooling.AbstractPoolingContainer
This should always be followed by a try/finally
getResults() - Method in interface com.palantir.util.paging.BasicResultsPage
Returns the results in the current page.
getResults() - Method in class com.palantir.util.paging.SimpleResultsPage
 
getReversed() - Method in class com.palantir.util.Pair
Returns a pair with the left and right reversed.
getRhSide() - Method in class com.palantir.util.Pair
Returns the right-hand side, or second, object of the pair.
getRightFunc() - Static method in class com.palantir.util.Pair
 
getSecureRandom() - Method in class com.palantir.common.random.SecureRandomPool
 
getServiceHint() - Method in exception com.palantir.common.remoting.ServiceNotAvailableException
 
getSize() - Method in class com.palantir.util.CacheStats
 
getSize() - Method in interface com.palantir.util.CacheStatsMBean
 
getStackTraceForConnection(MBeanServerConnection) - Static method in class com.palantir.util.debug.StackTraceUtils
 
getStackTraceForConnection(MBeanServerConnection, boolean) - Static method in class com.palantir.util.debug.StackTraceUtils
getStackTraceForConnection(MBeanServerConnection, boolean, StackTraceUtils.DumpDetail) - Static method in class com.palantir.util.debug.StackTraceUtils
 
getStatBeanName() - Method in class com.palantir.util.MBeanCache
 
getThreadDump() - Static method in class com.palantir.common.base.Throwables
Returns a dump of all threads.
getTimeMillis() - Method in interface com.palantir.common.time.Clock
Returns the time in milliseconds.
getTimeMillis() - Method in class com.palantir.common.time.SystemClock
 
getTokenForNextPage() - Method in class com.palantir.util.paging.SimpleTokenBackedResultsPage
 
getTokenForNextPage() - Method in interface com.palantir.util.paging.TokenBackedBasicResultsPage
Gets the token for the next page.
getUnchecked(Future<R>) - Static method in class com.palantir.atlasdb.futures.AtlasFutures
 
getValue() - Method in class com.palantir.util.AggregatingVersionedMetric
 
getValueFunction() - Static method in class com.palantir.common.collect.MapEntries
 
getVersionedValue() - Method in class com.palantir.util.AggregatingVersionedMetric
 
GZIP - com.palantir.common.compression.StreamCompression
 
GzipCompressingInputStream - Class in com.palantir.common.compression
 
GzipCompressingInputStream() - Constructor for class com.palantir.common.compression.GzipCompressingInputStream
 

H

handleInvocation(Object, Method, Object[]) - Method in class com.palantir.common.proxy.ExperimentRunningProxy
 
handleInvocation(Object, Method, Object[]) - Method in class com.palantir.common.proxy.MultiDelegateProxy
 
handleInvocation(Object, Method, Object[]) - Method in class com.palantir.common.proxy.PredicateSwitchedProxy
 
handleInvocation(Object, Method, Object[]) - Method in class com.palantir.common.proxy.ReplaceIfExceptionMatchingProxy
 
hasCauseInCausalChain(T, Class<? extends T>) - Static method in class com.palantir.common.base.Throwables
Returns true iff an exception of type causeClass exists somewhere in the causal chain.
hash(Hasher) - Method in class com.palantir.util.crypto.Sha256Hash
 
hashCode() - Method in class com.palantir.util.crypto.Sha256Hash
 
hashCode() - Method in class com.palantir.util.Mutable
Returns a hash code of the Mutable's value.
hashCode() - Method in class com.palantir.util.paging.SimpleResultsPage
 
hashCode() - Method in class com.palantir.util.paging.SimpleTokenBackedResultsPage
 
hashCode() - Method in class com.palantir.util.Pair
Returns a hash code of the Pair's values.
HeaderAccessUtils - Class in com.palantir.common.remoting
This class is useful for accessing HTTP headers in a case-insensitive manner.
hintBatchSize(int) - Method in class com.palantir.common.base.BatchingVisitableView
 
hintPageSize(BatchingVisitable<T>, int) - Static method in class com.palantir.common.base.BatchingVisitables
This method will wrap the passed visitable so it is called with the passed pageSize when it is called.
hydrateFromBytes(byte[]) - Method in interface com.palantir.common.persist.Persistable.Hydrator
 
HYDRATOR_NAME - Static variable in interface com.palantir.common.persist.Persistable
 

I

immutableCopy() - Method in class com.palantir.common.base.BatchingVisitableView
Returns an immutable copy of the elements in this visitable.
immutableCopy() - Method in class com.palantir.common.collect.IterableView
Returns an immutable copy of the current contents of this iterable view.
immutableSetCopy() - Method in class com.palantir.common.base.BatchingVisitableView
Returns an immutable copy of the elements in this visitable.
immutableSetCopy() - Method in class com.palantir.common.collect.IterableView
Returns an immutable copy of the current contents of this iterable view.
ImmutablesStyles - Interface in com.palantir.common.annotations
 
ImmutablesStyles.AllParametersStyle - Annotation Type in com.palantir.common.annotations
 
ImmutablesStyles.AttributeBuilderDetectionStyle - Annotation Type in com.palantir.common.annotations
 
ImmutablesStyles.NoStagedBuilderStyle - Annotation Type in com.palantir.common.annotations
 
ImmutablesStyles.PackageVisibleImmutablesStyle - Annotation Type in com.palantir.common.annotations
 
ImmutablesStyles.StagedBuilderStyle - Annotation Type in com.palantir.common.annotations
 
ImmutablesStyles.WeakInterningImmutablesStyle - Annotation Type in com.palantir.common.annotations
 
incrementCleanups() - Method in class com.palantir.util.CacheStats
 
incrementHits() - Method in class com.palantir.util.CacheStats
 
incrementMisses() - Method in class com.palantir.util.CacheStats
 
incrementPuts() - Method in class com.palantir.util.CacheStats
 
init(R) - Method in class com.palantir.async.initializer.Callback
The method to be executed.
init(R) - Method in class com.palantir.async.initializer.LambdaCallback
 
init(T) - Method in class com.palantir.async.initializer.Callback.CallChain
 
initialize(boolean) - Method in class com.palantir.async.initializer.AsyncInitializer
Initialization method that must be called to initialize the object before it is used.
initialize(R) - Method in interface com.palantir.async.initializer.CallbackInitializable
 
INITIALIZING - com.palantir.async.initializer.AsyncInitializationState.State
 
instant() - Method in interface com.palantir.common.time.Clock
 
InterruptibleFuture<V> - Class in com.palantir.common.concurrent
A RunnableFuture whose get methods will never throw CancellationException unless the task was never run.
InterruptibleFuture() - Constructor for class com.palantir.common.concurrent.InterruptibleFuture
 
InterruptibleProxy - Class in com.palantir.common.proxy
Proxy that calls the requested method in another thread waits on a Future.
invoke(Object, Method, Object[]) - Method in class com.palantir.common.proxy.AbstractDelegatingInvocationHandler
 
invoke(Object, Method, Object[]) - Method in class com.palantir.common.proxy.DelayProxy
 
invoke(Object, Method, Object[]) - Method in class com.palantir.common.proxy.InterruptibleProxy
 
invoke(Object, Method, Object[]) - Method in class com.palantir.common.proxy.TimingProxy
 
IP_ADDRESS_REDACTED - Static variable in class com.palantir.util.debug.StackTraceUtils
 
IP_ADDRESS_REGEX - Static variable in class com.palantir.util.debug.StackTraceUtils
 
isAssertEnabled() - Static method in class com.palantir.util.AssertUtils
 
isBefore(NanoTime) - Method in class com.palantir.common.time.NanoTime
 
isCancelled() - Method in class com.palantir.common.concurrent.InterruptibleFuture
 
isDone() - Method in class com.palantir.common.concurrent.InterruptibleFuture
 
isEmpty() - Method in class com.palantir.common.base.BatchingVisitableView
 
isEmpty() - Method in class com.palantir.common.collect.IterableView
 
isEmpty(BatchingVisitable<T>) - Static method in class com.palantir.common.base.BatchingVisitables
 
isEqual(BatchingVisitable<T>, Iterable<T>) - Static method in class com.palantir.common.base.BatchingVisitables
 
isEqual(BatchingVisitable<T>, Iterator<T>) - Static method in class com.palantir.common.base.BatchingVisitables
 
isEqual(Iterable<T>) - Method in class com.palantir.common.base.BatchingVisitableView
 
isEqual(Iterator<T>) - Method in class com.palantir.common.base.BatchingVisitableView
 
isErr() - Method in interface com.palantir.util.result.Result
 
isInitialized() - Method in class com.palantir.async.initializer.AsyncInitializer
 
isLocked(Iterable<T>) - Method in class com.palantir.util.MutuallyExclusiveSetLock
Returns true if all the items are locked on the current thread.
isOk() - Method in interface com.palantir.util.result.Result
 
isOwned() - Method in interface com.palantir.util.Ownable
 
isTrue() - Method in enum com.palantir.util.PersistableBoolean
 
isValid() - Method in class com.palantir.util.SoftCache.CacheEntry
 
IterableUtils - Class in com.palantir.common.collect
 
IterableView<T> - Class in com.palantir.common.collect
A wrapper for an iterable that gives it super chaining powers.
IterableView() - Constructor for class com.palantir.common.collect.IterableView
 
iterator() - Method in class com.palantir.common.collect.EmptyQueue
 
iterator() - Method in class com.palantir.common.collect.IterableView
 
iterator() - Method in class com.palantir.util.paging.AbstractPagingIterable
 
IteratorUtils - Class in com.palantir.common.collect
 

J

JMXUtils - Class in com.palantir.util
 
JMXUtils.AllowConnections - Enum in com.palantir.util
 

K

KEEP_ALL_BATCH_SIZE - Static variable in class com.palantir.common.base.BatchingVisitables
 
KeyedReference - Interface in com.palantir.util
 
KeyedSoftReference<K,​V> - Class in com.palantir.util
 
KeyedSoftReference(K, V) - Constructor for class com.palantir.util.KeyedSoftReference
 
KeyedSoftReference(K, V, ReferenceQueue<V>) - Constructor for class com.palantir.util.KeyedSoftReference
 
KeyedWeakReference<K,​V> - Class in com.palantir.util
 
KeyedWeakReference(K, V) - Constructor for class com.palantir.util.KeyedWeakReference
 
KeyedWeakReference(K, V, ReferenceQueue<V>) - Constructor for class com.palantir.util.KeyedWeakReference
 
keySet() - Method in class com.palantir.util.SoftCache
 

L

LambdaCallback<R> - Class in com.palantir.async.initializer
Convenience class for creating callbacks using lambda expressions.
lhSide - Variable in class com.palantir.util.Pair
The left-hand side, or first, object in the Pair.
limit(int) - Method in class com.palantir.common.collect.IterableView
 
limit(long) - Method in class com.palantir.common.base.BatchingVisitableView
 
limit(BatchingVisitable<T>, long) - Static method in class com.palantir.common.base.BatchingVisitables
 
LINE_ENDING - Static variable in class com.palantir.util.debug.StackTraceUtils
 
LOCALHOST_ONLY - com.palantir.util.JMXUtils.AllowConnections
 
lockOnObjects(Iterable<T>) - Method in class com.palantir.util.MutuallyExclusiveSetLock
Attempts to acquire the locks in increasing order and may block.
lockOnObjectsInterruptibly(Iterable<T>) - Method in class com.palantir.util.MutuallyExclusiveSetLock
 
log(Consumer<SafeLogger>) - Method in class com.palantir.util.RateLimitedLogger
 
LoggingOperationTimer - Class in com.palantir.util.timer
 
LZ4 - com.palantir.common.compression.StreamCompression
 
LZ4CompressingInputStream - Class in com.palantir.common.compression
InputStream that wraps a delegate InputStream, compressing its contents as they are read.
LZ4CompressingInputStream(InputStream) - Constructor for class com.palantir.common.compression.LZ4CompressingInputStream
 
LZ4CompressingInputStream(InputStream, int) - Constructor for class com.palantir.common.compression.LZ4CompressingInputStream
 

M

map(Function<T, U>) - Method in interface com.palantir.common.base.ClosableIterator
 
MapEntries - Class in com.palantir.common.collect
 
Maps2 - Class in com.palantir.common.collect
 
mbean - Variable in class com.palantir.util.MBeanCache
 
MBeanCache<K,​V> - Class in com.palantir.util
Registers an mbean useful for tracking cache operations.
MBeanCache() - Constructor for class com.palantir.util.MBeanCache
 
mergeIterators(Iterator<? extends T>, Iterator<? extends T>, Comparator<? super T>, Function<? super Pair<T, T>, ? extends T>) - Static method in class com.palantir.common.collect.IteratorUtils
The iterators provided to this function have to be sorted and strictly increasing.
min(long) - Static method in class com.palantir.util.AggregatingVersionedSupplier
 
mkdirsWithRetry(File) - Static method in class com.palantir.util.file.TempFileUtils
A thread-safer mkdirs.
moreResultsAvailable() - Method in interface com.palantir.util.paging.BasicResultsPage
Identifies if more results are available.
moreResultsAvailable() - Method in class com.palantir.util.paging.SimpleResultsPage
 
MultiDelegateProxy<T> - Class in com.palantir.common.proxy
This class will delegate functionality and return the value (or throw the exception) of one of the delegates.
MultiplexingCompletionService<K,​V> - Class in com.palantir.common.concurrent
A MultiplexingCompletionService is much like a ExecutorCompletionService, but supports multiple delegate ExecutorServices feeding in to a single shared BlockingQueue.
Mutable<T> - Class in com.palantir.util
Simple generic class to use in situations where something needs to be final to be passed into a closure.
Mutable() - Constructor for class com.palantir.util.Mutable
Constructs and returns an empty Mutable.
Mutable(T) - Constructor for class com.palantir.util.Mutable
Constructs and returns a new Mutable containing the given val.
Mutables - Class in com.palantir.util
 
Mutables() - Constructor for class com.palantir.util.Mutables
 
MutuallyExclusiveSetLock<T> - Class in com.palantir.util
This class accepts a collection of Comparable objects, creates locks for each object, and then locks each object in order.
MutuallyExclusiveSetLock() - Constructor for class com.palantir.util.MutuallyExclusiveSetLock
Deprecated.
MutuallyExclusiveSetLock(boolean) - Constructor for class com.palantir.util.MutuallyExclusiveSetLock
Deprecated.
MutuallyExclusiveSetLock(boolean, Comparator<? super T>) - Constructor for class com.palantir.util.MutuallyExclusiveSetLock
MutuallyExclusiveSetLock.LockState<K> - Class in com.palantir.util
An instance of this class is returned by the MutuallyExclusiveSetLock.lockOnObjects() method.

N

NanoTime - Class in com.palantir.common.time
 
NanoTime() - Constructor for class com.palantir.common.time.NanoTime
 
newMBeanProxy(MBeanServerConnection, ObjectName, Class<T>) - Static method in class com.palantir.util.JMXUtils
This method allows you to get at a bean registered with the server.
newMutable() - Static method in class com.palantir.util.Mutables
Creates a new Mutable with a null value to start with.
newMutable(T) - Static method in class com.palantir.util.Mutables
Type-inferred factory method for Mutable
newProxyInstance(Class<T>, T, long) - Static method in class com.palantir.common.proxy.DelayProxy
 
newProxyInstance(Class<T>, T, long) - Static method in class com.palantir.common.proxy.SimulatingServerProxy
 
newProxyInstance(Class<T>, T, CancelDelegate) - Static method in class com.palantir.common.proxy.InterruptibleProxy
 
newProxyInstance(Class<T>, T, CancelDelegate, ExecutorService) - Static method in class com.palantir.common.proxy.InterruptibleProxy
 
newProxyInstance(Class<T>, T, OperationTimer) - Static method in class com.palantir.common.proxy.TimingProxy
 
newProxyInstance(Class<T>, T, Iterable<? extends T>) - Static method in class com.palantir.common.proxy.MultiDelegateProxy
This will copy off all the objects in delegatesToCall.
newProxyInstance(Class<T>, T, Supplier<? extends Iterable<? extends T>>) - Static method in class com.palantir.common.proxy.MultiDelegateProxy
For each method invoked on the returned object, Supplier.get() will be called and iterated over.
newProxyInstance(Class<T>, T, Supplier<Long>) - Static method in class com.palantir.common.proxy.DelayProxy
 
newProxyInstance(Class<T>, T, T...) - Static method in class com.palantir.common.proxy.MultiDelegateProxy
 
newProxyInstance(Supplier<T>, T, BooleanSupplier, BooleanSupplier, Class<T>, Runnable) - Static method in class com.palantir.common.proxy.ExperimentRunningProxy
 
newProxyInstance(T, T, Supplier<Boolean>, Class<T>) - Static method in class com.palantir.common.proxy.PredicateSwitchedProxy
 
newSoftCacheEntry(K, V) - Method in class com.palantir.util.SoftCache
 
newWeakCacheEntry(K, V) - Method in class com.palantir.util.SoftCache
 
NonDistributedCache<K,​V> - Interface in com.palantir.util
This is a minimal interface for a cache that is not distrubted and thus can support operations that are difficult over multiple boxes.
NONE - com.palantir.common.compression.StreamCompression
 
nonNullItems(Collection<T>) - Static method in class com.palantir.util.AssertUtils
 
noOp() - Static method in class com.palantir.async.initializer.Callback
Factory method for a callback that does nothing.
NotCurrentLeaderException - Exception in com.palantir.leader
Some operations may only complete if they are run on the leader.
NotCurrentLeaderException(String, HostAndPort, Arg<?>...) - Constructor for exception com.palantir.leader.NotCurrentLeaderException
 
NotCurrentLeaderException(String, Arg<?>...) - Constructor for exception com.palantir.leader.NotCurrentLeaderException
 
NotCurrentLeaderException(String, Throwable, HostAndPort, Arg<?>...) - Constructor for exception com.palantir.leader.NotCurrentLeaderException
 
NotCurrentLeaderException(String, Throwable, Arg<?>...) - Constructor for exception com.palantir.leader.NotCurrentLeaderException
 
noteFinished() - Method in class com.palantir.common.concurrent.InterruptibleFuture
 
NotInitializedException - Exception in com.palantir.exception
 
NotInitializedException(String) - Constructor for exception com.palantir.exception.NotInitializedException
 
NotInitializedException(String, Throwable) - Constructor for exception com.palantir.exception.NotInitializedException
 
notOwned(R) - Static method in interface com.palantir.util.Ownable
 
now() - Static method in class com.palantir.common.time.NanoTime
 
NULL - Static variable in interface com.palantir.util.jmx.OperationTimer.TimingState
 

O

OBJECT_NAME_PREFIX - Static variable in class com.palantir.util.MBeanCache
 
OBJECT_NAME_PREFIX - Static variable in class com.palantir.util.SoftCache
Deprecated.
ObjectInputStreamFactory - Interface in com.palantir.util
 
of() - Static method in class com.palantir.common.collect.EmptyQueue
 
of(boolean) - Static method in enum com.palantir.util.PersistableBoolean
 
of(BatchingVisitable<T>) - Static method in class com.palantir.common.base.BatchingVisitableView
 
of(Iterable<? extends T>) - Static method in class com.palantir.common.collect.IterableView
 
of(Callable<V>) - Static method in class com.palantir.common.concurrent.InterruptibleFuture
 
of(Consumer<R>) - Static method in class com.palantir.async.initializer.LambdaCallback
Simple version of LambdaCallback.singleAttempt(Consumer, BiConsumer) when no cleanup is necessary on failure.
of(T...) - Static method in class com.palantir.common.collect.IterableView
 
of(T, long) - Static method in interface com.palantir.util.VersionedType
 
offer(E) - Method in class com.palantir.common.collect.EmptyQueue
 
ofLength(int) - Static method in class com.palantir.common.random.RandomBytes
 
ok(T) - Static method in interface com.palantir.util.result.Result
 
onInitializationFailureCleanup(R, Throwable) - Method in interface com.palantir.async.initializer.CallbackInitializable
If #initialize(R) failing can result in a state where cleanup is necessary, override this method.
OperationTimer - Interface in com.palantir.util.jmx
This is a simple timer class that is asked to begin a timer and end after the operation is done.
OperationTimer.TimingState - Interface in com.palantir.util.jmx
 
OptionalResolver - Class in com.palantir.util
 
OrderedSublistProvider<T> - Interface in com.palantir.common.base
Provides sublists of a list of T's, where each T is identified by a long.
Ownable<R> - Interface in com.palantir.util
 
owned(R) - Static method in interface com.palantir.util.Ownable
 

P

PageDrainer<T> - Class in com.palantir.util.paging
 
PageDrainer(PageGetter<T>) - Constructor for class com.palantir.util.paging.PageDrainer
 
PageGetter<T> - Interface in com.palantir.util.paging
 
PagingIterator(AbstractPagingIterable<T, P>) - Constructor for class com.palantir.util.paging.AbstractPagingIterable.PagingIterator
 
Pair<V,​W> - Class in com.palantir.util
A generic class for handling pairs of things.
Pair() - Constructor for class com.palantir.util.Pair
Creates a new instance of Pair with both sides of the pair set to null.
Pair(V, W) - Constructor for class com.palantir.util.Pair
Creates a new instance of Pair with the left and right side set to the provided objects.
PalantirInterruptedException - Exception in com.palantir.exception
The contract for InterruptedException states that if you don't handle the interrupt you should either drop the interrupt flag on the thread or rethrow an InterruptedException.
PalantirInterruptedException(String) - Constructor for exception com.palantir.exception.PalantirInterruptedException
 
PalantirInterruptedException(String, Throwable) - Constructor for exception com.palantir.exception.PalantirInterruptedException
 
PalantirInterruptedException(Throwable) - Constructor for exception com.palantir.exception.PalantirInterruptedException
 
PalantirRuntimeException - Exception in com.palantir.common.exception
Base class of all unchecked exceptions in the Palantir platform.
PalantirRuntimeException() - Constructor for exception com.palantir.common.exception.PalantirRuntimeException
 
PalantirRuntimeException(String) - Constructor for exception com.palantir.common.exception.PalantirRuntimeException
 
PalantirRuntimeException(String, Throwable) - Constructor for exception com.palantir.common.exception.PalantirRuntimeException
 
PalantirRuntimeException(Throwable) - Constructor for exception com.palantir.common.exception.PalantirRuntimeException
 
PalantirSqlException - Exception in com.palantir.exception
SQLExceptions are checked.
PalantirSqlException(PalantirSqlException.DO_NOT_SET_INITIAL_SQL_EXCEPTION) - Constructor for exception com.palantir.exception.PalantirSqlException
 
PalantirSqlException(PalantirSqlException.DO_NOT_SET_INITIAL_SQL_EXCEPTION, String) - Constructor for exception com.palantir.exception.PalantirSqlException
 
PalantirSqlException(PalantirSqlException.SET_INITIAL_SQL_EXCEPTION) - Constructor for exception com.palantir.exception.PalantirSqlException
This is not safe to use with Throwables.chain()
PalantirSqlException(PalantirSqlException.SET_INITIAL_SQL_EXCEPTION, String) - Constructor for exception com.palantir.exception.PalantirSqlException
 
PalantirSqlException(String, Throwable) - Constructor for exception com.palantir.exception.PalantirSqlException
Deprecated.
Do not use! This should only be used by Throwables.rewrap which constructs new exceptions via reflection and relies on constructors with particular signatures being present.
PalantirSqlException(String, SQLException) - Constructor for exception com.palantir.exception.PalantirSqlException
 
PalantirSqlException.DO_NOT_SET_INITIAL_SQL_EXCEPTION - Enum in com.palantir.exception
 
PalantirSqlException.SET_INITIAL_SQL_EXCEPTION - Enum in com.palantir.exception
 
partition(int) - Method in class com.palantir.common.collect.IterableView
 
peek() - Method in class com.palantir.common.collect.EmptyQueue
 
Persistable - Interface in com.palantir.common.persist
Classes implementing Persistable must also have a static field called BYTES_HYDRATOR that implements the Persistable.Hydrator interface.
Persistable.Hydrator<T> - Interface in com.palantir.common.persist
 
PersistableBoolean - Enum in com.palantir.util
 
Persistables - Class in com.palantir.common.persist
 
Persistables() - Constructor for class com.palantir.common.persist.Persistables
 
persistAll(Iterable<? extends Persistable>) - Static method in class com.palantir.common.persist.Persistables
 
persistToBytes() - Method in interface com.palantir.common.persist.Persistable
 
persistToBytesFunction() - Static method in class com.palantir.common.persist.Persistables
 
pluralize(String) - Static method in class com.palantir.util.debug.StackTraceUtils
This function pluralizes the given text and now accounts for three capitalization cases: lower case, Camel Case, and ALL CAPS.
pluralizeWord(String, int) - Static method in class com.palantir.util.debug.StackTraceUtils
Pluralizes a word if count != 1.
plus(Duration) - Method in class com.palantir.common.time.NanoTime
 
poll() - Method in class com.palantir.common.collect.EmptyQueue
 
poll() - Method in class com.palantir.common.concurrent.MultiplexingCompletionService
 
poll(long, TimeUnit) - Method in class com.palantir.common.concurrent.MultiplexingCompletionService
 
PoolingContainer<T> - Interface in com.palantir.common.pooling
 
PredicateSwitchedProxy<T> - Class in com.palantir.common.proxy
 
PrefetchingBatchingVisitable<T> - Class in com.palantir.common.base
A BatchingVisitable that will prefetch in a background thread.
PrefetchingBatchingVisitable(BatchingVisitable<T>, int, ExecutorService, String) - Constructor for class com.palantir.common.base.PrefetchingBatchingVisitable
 
processTrace(String, String[], boolean) - Static method in class com.palantir.util.debug.StackTraceUtils
 
programmaticThreadDump() - Static method in class com.palantir.util.debug.ThreadDumps
 
programmaticThreadDump(boolean) - Static method in class com.palantir.util.debug.ThreadDumps
 
put(Map<? super K, ? super V>, Map.Entry<K, V>) - Static method in class com.palantir.common.collect.MapEntries
 
put(K, V) - Method in interface com.palantir.util.DistributedCacheMgrCache
 
put(K, V) - Method in class com.palantir.util.SoftCache
Adds an object to the cache.
putAll(Map<? extends K, ? extends V>) - Method in class com.palantir.util.SoftCache
 
putAll(Map<K, V>, Iterable<? extends Map.Entry<? extends K, ? extends V>>) - Static method in class com.palantir.common.collect.MapEntries
 
putAllIfAbsent(Map<? extends K, ? extends V>) - Method in class com.palantir.util.SoftCache
 
putAllIfAbsent(Map<? extends K, ? extends V>, long) - Method in class com.palantir.util.SoftCache
 
putIfAbsent(K, V) - Method in class com.palantir.util.SoftCache
If the specified key is not already associated with a value, associate it with the given value.

Q

QUORUM - com.palantir.util.io.AvailabilityRequirement
 

R

RandomBytes - Class in com.palantir.common.random
 
RateLimitedLogger - Class in com.palantir.util
 
RateLimitedLogger(SafeLogger, double) - Constructor for class com.palantir.util.RateLimitedLogger
 
read() - Method in class com.palantir.common.compression.BufferedDelegateInputStream
 
read() - Method in class com.palantir.common.io.ConcatenatedInputStream
 
read(byte[], int, int) - Method in class com.palantir.common.compression.BufferedDelegateInputStream
Reads up to len bytes into the provided byte array b.
read(byte[], int, int) - Method in class com.palantir.common.io.ConcatenatedInputStream
 
READ_FAILED - Static variable in class com.palantir.common.compression.BufferedDelegateInputStream
 
redact(CharSequence) - Static method in class com.palantir.util.debug.StackTraceUtils
 
referenceQueue - Variable in class com.palantir.util.SoftCache
 
refill() - Method in class com.palantir.common.compression.BufferedDelegateInputStream
Refills the internal buffer from the delegate InputStream.
refill() - Method in class com.palantir.common.compression.LZ4CompressingInputStream
 
registerMBean() - Method in class com.palantir.util.MBeanCache
Make sure to get a unique name on this object before trying to register this cache with JMX.
registerMBean(String) - Method in class com.palantir.util.MBeanCache
Registers an mbean for this cache with the provided object name.
registerMBeanCatchAndLogExceptions(Object, String) - Static method in class com.palantir.util.JMXUtils
Simple method to register a bean with the server.
registerMBeanWeakRefPlusCatchAndLogExceptions(T, Class<T>, String) - Static method in class com.palantir.util.JMXUtils
You must retain a reference to the returned DynamicMBean for as long as you wish this bean to be registered.
remove(K) - Method in class com.palantir.util.SoftCache
Removes an object from the cache.
removeMatchingKeys(Predicate<K>) - Method in class com.palantir.util.SoftCache
 
ReplaceIfExceptionMatchingProxy<T> - Class in com.palantir.common.proxy
 
resolve(Optional<T>, Optional<T>) - Static method in class com.palantir.util.OptionalResolver
Returns a single value corresponding to the value that is present in one or more of the Optionals provided.
resource() - Method in interface com.palantir.util.Ownable
 
Result<T,​E> - Interface in com.palantir.util.result
 
retrying(Consumer<R>, BiConsumer<R, Throwable>) - Static method in class com.palantir.async.initializer.LambdaCallback
Creates a callback that will retry initialization until cleanup also throws.
retryUnlessCleanupThrowsCallback() - Method in interface com.palantir.async.initializer.CallbackInitializable
Returns a Callback that will retry initialization on failure, unless the cleanup task also throws, in which case the exception thrown by the cleanup task is propagated.
returnResource(T) - Method in class com.palantir.common.pooling.AbstractPoolingContainer
This method should only be called in the finally block of a try/finally
rewrap(String, T) - Static method in class com.palantir.common.base.Throwables
Rewraps the given throwable in a newly created throwable of the same runtime type in order to capture the current thread's stack trace.
rewrap(T) - Static method in class com.palantir.common.base.Throwables
Rewraps the given throwable in a newly created throwable of the same runtime type in order to capture the current thread's stack trace.
rewrapAndThrowIfInstance(String, Throwable, Class<K>) - Static method in class com.palantir.common.base.Throwables
if (t instanceof K) throw Throwables.rewrap((K)t);
rewrapAndThrowIfInstance(Throwable, Class<K>) - Static method in class com.palantir.common.base.Throwables
if (t instanceof K) throw Throwables.rewrap((K)t);
rewrapAndThrowUncheckedException(String, Throwable) - Static method in class com.palantir.common.base.Throwables
If Throwable is a RuntimeException or Error, rewrap and throw it.
rewrapAndThrowUncheckedException(Throwable) - Static method in class com.palantir.common.base.Throwables
If Throwable is a RuntimeException or Error, rewrap and throw it.
rhSide - Variable in class com.palantir.util.Pair
The right-hand side, or second, object in the Pair.
run() - Method in interface com.palantir.common.base.RunnableCheckedException
 
run() - Method in class com.palantir.common.concurrent.InterruptibleFuture
 
run(TimedRunner.TaskContext<T>) - Method in class com.palantir.util.TimedRunner
 
RunnableCheckedException<E extends Exception> - Interface in com.palantir.common.base
 
runOnceOnly(R) - Method in class com.palantir.async.initializer.Callback
Try init() once only, performing any necessary cleanup
runWithPooledResource(Function<T, V>) - Method in class com.palantir.common.pooling.AbstractPoolingContainer
This will run the provided function with a pooled resource.
runWithPooledResource(Function<T, V>) - Method in class com.palantir.common.pooling.ForwardingPoolingContainer
 
runWithPooledResource(Function<T, V>) - Method in interface com.palantir.common.pooling.PoolingContainer
 
runWithPooledResource(FunctionCheckedException<T, V, K>) - Method in class com.palantir.common.pooling.AbstractPoolingContainer
 
runWithPooledResource(FunctionCheckedException<T, V, K>) - Method in class com.palantir.common.pooling.ForwardingPoolingContainer
 
runWithPooledResource(FunctionCheckedException<T, V, K>) - Method in interface com.palantir.common.pooling.PoolingContainer
 
runWithRetry(R) - Method in class com.palantir.async.initializer.Callback
Keep retrying init(), performing any necessary cleanup, until it succeeds unless cleanup() throws or a shutdown signal has been sent.

S

SafeShutdownRunner - Class in com.palantir.util
 
SafeSSLPeerUnverifiedException - Exception in com.palantir.exception
 
SafeSSLPeerUnverifiedException(String, Arg<?>...) - Constructor for exception com.palantir.exception.SafeSSLPeerUnverifiedException
 
satisfies(int, int) - Method in enum com.palantir.util.io.AvailabilityRequirement
 
SecureRandomPool - Class in com.palantir.common.random
 
SecureRandomPool(String, int) - Constructor for class com.palantir.common.random.SecureRandomPool
Creates a SecureRandomPool using the specified algorithm.
SecureRandomPool(String, int, SecureRandom) - Constructor for class com.palantir.common.random.SecureRandomPool
Creates a SecureRandomPool using the specified algorithm.
serializeToBase64String() - Method in class com.palantir.util.crypto.Sha256Hash
 
serializeToHexString() - Method in class com.palantir.util.crypto.Sha256Hash
 
SerializingUtils - Class in com.palantir.common.proxy
 
ServiceNotAvailableException - Exception in com.palantir.common.remoting
If a server is shutting down or cannot respond to a call for another reason this exception may be thrown.
ServiceNotAvailableException(String, HostAndPort, Arg<?>...) - Constructor for exception com.palantir.common.remoting.ServiceNotAvailableException
 
ServiceNotAvailableException(String, Arg<?>...) - Constructor for exception com.palantir.common.remoting.ServiceNotAvailableException
 
ServiceNotAvailableException(String, Throwable, HostAndPort, Arg<?>...) - Constructor for exception com.palantir.common.remoting.ServiceNotAvailableException
 
ServiceNotAvailableException(String, Throwable, Arg<?>...) - Constructor for exception com.palantir.common.remoting.ServiceNotAvailableException
 
ServiceNotAvailableException(Throwable, Arg<?>...) - Constructor for exception com.palantir.common.remoting.ServiceNotAvailableException
 
set(T) - Method in class com.palantir.util.Mutable
Sets the enclosed object for an empty Mutable.
setMaxCacheSize(int) - Method in class com.palantir.util.CacheStats
 
setMaxCacheSize(int) - Method in interface com.palantir.util.CacheStatsMBean
 
setMaxCacheSize(int) - Method in class com.palantir.util.MBeanCache
 
setMaxCacheSize(int) - Method in class com.palantir.util.SoftCache
 
setName(String) - Method in class com.palantir.util.MBeanCache
Sets the name for this cache.
Sha256Hash - Class in com.palantir.util.crypto
A SHA-256 hash.
Sha256Hash(byte[]) - Constructor for class com.palantir.util.crypto.Sha256Hash
Constructs a type-safe Sha256Hash object from the given hash bytes.
Sha256Hash(HashCode) - Constructor for class com.palantir.util.crypto.Sha256Hash
 
shortcircuitingCaseInsensitiveContainsEntry(Map<String, Collection<String>>, String, String) - Static method in class com.palantir.common.remoting.HeaderAccessUtils
Compares the keys of the map to the header in a case-insensitive manner; upon finding a match, compares the associated collection of strings from the map with the value, returning true iff this contains a match.
shortcircuitingCaseInsensitiveGet(Map<String, Collection<String>>, String) - Static method in class com.palantir.common.remoting.HeaderAccessUtils
Compares the keys of the map to the header in a case-insensitive manner.
shutdownPooling() - Method in class com.palantir.common.pooling.AbstractPoolingContainer
This method will call AbstractPoolingContainer.cleanupForDiscard(Object) on everything that is in the pool and will make the pool of size zero.
shutdownPooling() - Method in class com.palantir.common.pooling.ForwardingPoolingContainer
 
shutdownPooling() - Method in interface com.palantir.common.pooling.PoolingContainer
This method will discard pooled objects and cleanup any resources they are taking up.
shutdownSafely(Runnable) - Method in class com.palantir.util.SafeShutdownRunner
 
SimpleResultsPage<T> - Class in com.palantir.util.paging
Supplies a simple result page.
SimpleResultsPage(Iterable<T>) - Constructor for class com.palantir.util.paging.SimpleResultsPage
Constructs a page of iterable chunks.
SimpleResultsPage(Iterable<T>, boolean) - Constructor for class com.palantir.util.paging.SimpleResultsPage
Constructs a page of iterable chunks of results.
SimpleTokenBackedResultsPage<T,​TOKEN> - Class in com.palantir.util.paging
 
SimpleTokenBackedResultsPage(TOKEN, Iterable<T>) - Constructor for class com.palantir.util.paging.SimpleTokenBackedResultsPage
 
SimpleTokenBackedResultsPage(TOKEN, Iterable<T>, boolean) - Constructor for class com.palantir.util.paging.SimpleTokenBackedResultsPage
 
SimulatingServerProxy - Class in com.palantir.common.proxy
A static method to return a proxy which simulates a remote server.
singleAttempt(Consumer<R>, BiConsumer<R, Throwable>) - Static method in class com.palantir.async.initializer.LambdaCallback
Creates a callback that will attempt to initialize once.
singleAttemptCallback() - Method in interface com.palantir.async.initializer.CallbackInitializable
Returns a Callback that runs initialize only once.
singleton(T) - Static method in class com.palantir.common.base.BatchingVisitables
 
size() - Method in class com.palantir.common.base.BatchingVisitableView
 
size() - Method in class com.palantir.common.collect.EmptyQueue
 
size() - Method in class com.palantir.common.collect.IterableView
 
size() - Method in class com.palantir.util.ByteArrayIOStream
Returns the number of bytes written to this stream.
size() - Method in class com.palantir.util.MBeanCache
 
size() - Method in interface com.palantir.util.NonDistributedCache
 
size() - Method in class com.palantir.util.SoftCache
 
skip(int) - Method in class com.palantir.common.collect.IterableView
 
skip(long) - Method in class com.palantir.common.base.BatchingVisitableView
 
skip(BatchingVisitable<T>, long) - Static method in class com.palantir.common.base.BatchingVisitables
 
sleepInterval() - Method in class com.palantir.async.initializer.AsyncInitializer
 
sleepUntil(NanoTime) - Static method in class com.palantir.common.time.NanoTime
Sleep for a period of time, guaranteeing that the nanosecond precision clock has seen that period of time elapsed.
SoftCache<K,​V> - Class in com.palantir.util
Thread Safe
SoftCache() - Constructor for class com.palantir.util.SoftCache
 
SoftCache(int) - Constructor for class com.palantir.util.SoftCache
 
SoftCache.CacheEntry<V> - Class in com.palantir.util
CacheEntry is a cache entry that stores its value as a soft reference.
SoftCache.SoftCacheEntry<K,​V> - Class in com.palantir.util
 
SoftCache.WeakCacheEntry<K,​V> - Class in com.palantir.util
 
spliterator() - Method in class com.palantir.common.collect.IterableView
 
splitStackTrace(String) - Static method in class com.palantir.util.debug.StackTraceUtils
 
SQL_ORACLE_LIMIT_OFFSET_QUERY - Static variable in class com.palantir.nexus.db.SQLConstants
Oracle limit and offset query syntax (paging).
SQL_ORACLE_LIMIT_QUERY - Static variable in class com.palantir.nexus.db.SQLConstants
Oracle limit query syntax.
SQLConstants - Class in com.palantir.nexus.db
 
SQLConstants() - Constructor for class com.palantir.nexus.db.SQLConstants
 
StackTraceUtils - Class in com.palantir.util.debug
 
startLocalJMXServer(int, JMXUtils.AllowConnections) - Static method in class com.palantir.util.JMXUtils
Programmatically starts a JMX server.
stopWhen(Predicate<T>) - Method in interface com.palantir.common.base.ClosableIterator
 
stream() - Method in interface com.palantir.common.base.ClosableIterator
 
stream() - Method in class com.palantir.common.collect.IterableView
Returns a sequential Stream with the contents as its source.
StreamCompression - Enum in com.palantir.common.compression
 
submit(Callable<T>) - Method in class com.palantir.common.concurrent.CheckedRejectionExecutorService
 
submit(K, Callable<V>) - Method in class com.palantir.common.concurrent.MultiplexingCompletionService
Submits a task to be run on a specific executor.
submitCallable(Callable<T>) - Method in class com.palantir.common.concurrent.BlockingWorkerPool
Submits a callable task to the pool.
submitCallableUnchecked(Callable<T>) - Method in class com.palantir.common.concurrent.BlockingWorkerPool
Same as BlockingWorkerPool.submitCallable(Callable) but will wrap any InterruptedException in a RuntimeException.
submitTask(Runnable) - Method in class com.palantir.common.concurrent.BlockingWorkerPool
Submits a task to the pool.
SystemClock - Class in com.palantir.common.time
Simple clock implementation based on System.currentTimeMillis()
SystemClock() - Constructor for class com.palantir.common.time.SystemClock
 

T

TableMappingNotFoundException - Exception in com.palantir.common.exception
 
TableMappingNotFoundException(String) - Constructor for exception com.palantir.common.exception.TableMappingNotFoundException
 
TableMappingNotFoundException(String, Throwable) - Constructor for exception com.palantir.common.exception.TableMappingNotFoundException
 
TableMappingNotFoundException(Throwable) - Constructor for exception com.palantir.common.exception.TableMappingNotFoundException
 
take(BatchingVisitable<T>, int) - Static method in class com.palantir.common.base.BatchingVisitables
 
take(BatchingVisitable<T>, int, boolean) - Static method in class com.palantir.common.base.BatchingVisitables
 
task() - Method in interface com.palantir.util.TimedRunner.TaskContext
Executed to shut down an object.
taskFailureHandler() - Method in interface com.palantir.util.TimedRunner.TaskContext
Executed only if the task times out or otherwise has an exception.
TempFileUtils - Class in com.palantir.util.file
 
ThreadDumps - Class in com.palantir.util.debug
 
ThreadDumps() - Constructor for class com.palantir.util.debug.ThreadDumps
 
threadToString(ThreadInfo, Object[], int[]) - Static method in class com.palantir.util.debug.StackTraceUtils
 
Throwables - Class in com.palantir.common.base
Utilities for creating and propagating exceptions.
throwCauseAsUnchecked(Exception) - Static method in class com.palantir.common.base.Throwables
 
throwIfInstance(Throwable, Class<K>) - Static method in class com.palantir.common.base.Throwables
if (t instanceof K) throw (K)t;
throwIfUncheckedException(Throwable) - Static method in class com.palantir.common.base.Throwables
Will simply rethrow the exception if it is a RuntimeException or an Error
throwUncheckedException(Throwable) - Static method in class com.palantir.common.base.Throwables
Throws the input Throwable if it is a RuntimeException or Error, otherwise wraps it in a PalantirRuntimeException.
TimedRunner - Class in com.palantir.util
 
TimedRunner.TaskContext<T> - Interface in com.palantir.util
 
TimingProxy - Class in com.palantir.common.proxy
 
toByteArray() - Method in class com.palantir.util.ByteArrayIOStream
Returns a copy of the bytes written to this stream.
toCollection(Iterable<T>) - Static method in class com.palantir.common.collect.IterableUtils
 
toCollection(Iterable<T>, int) - Static method in class com.palantir.common.collect.IterableUtils
 
TokenBackedBasicResultsPage<T,​TOKEN> - Interface in com.palantir.util.paging
Represents a results page that is backed by TOKEN.
toMap(Iterable<Map.Entry<K, V>>) - Static method in class com.palantir.common.collect.MapEntries
 
toRemovableCollection(Iterable<T>) - Static method in class com.palantir.common.collect.IterableUtils
 
toString() - Method in class com.palantir.common.collect.IterableView
 
toString() - Method in class com.palantir.util.crypto.Sha256Hash
 
toString() - Method in class com.palantir.util.Mutable
 
toString() - Method in class com.palantir.util.paging.SimpleResultsPage
 
toString() - Method in class com.palantir.util.paging.SimpleTokenBackedResultsPage
 
toString() - Method in class com.palantir.util.Pair
Returns a String representation of both items in the pair, left side first.
toString() - Method in class com.palantir.util.SoftCache.CacheEntry
 
toString() - Method in class com.palantir.util.SoftCache
 
transform(Function<? super T, ? extends U>) - Method in class com.palantir.common.base.BatchingVisitableView
 
transform(Function<? super T, ? extends U>) - Method in class com.palantir.common.collect.IterableView
 
transform(BatchingVisitable<F>, Function<? super F, ? extends T>) - Static method in class com.palantir.common.base.BatchingVisitables
 
transform(Iterable<F>, Function<? super F, ? extends T>) - Static method in class com.palantir.common.collect.IterableUtils
Returns an iterable that applies function to each element of fromIterable.
transformBatch(Function<? super List<T>, ? extends List<U>>) - Method in class com.palantir.common.base.BatchingVisitableView
This can also be used to filter or multiply the input.
transformBatch(BatchingVisitable<F>, Function<? super List<F>, ? extends List<T>>) - Static method in class com.palantir.common.base.BatchingVisitables
 
transformKeys(Map<K1, V>, Function<K1, K2>) - Static method in class com.palantir.common.collect.Maps2
 
TRUE - com.palantir.util.PersistableBoolean
 
tryInitialize() - Method in class com.palantir.async.initializer.AsyncInitializer
Override this method with the calls to initialize an object that may fail.

U

UNINITIALIZED_VERSION - Static variable in class com.palantir.util.AggregatingVersionedSupplier
 
unique() - Method in class com.palantir.common.base.BatchingVisitableView
 
unique(BatchingVisitable<T>) - Static method in class com.palantir.common.base.BatchingVisitables
This is similar to the unix uniq command.
uniqueOn(Function<T, ?>) - Method in class com.palantir.common.base.BatchingVisitableView
 
uniqueOn(BatchingVisitable<T>, Function<T, ?>) - Static method in class com.palantir.common.base.BatchingVisitables
 
unlock() - Method in class com.palantir.util.MutuallyExclusiveSetLock.LockState
Unlocks the objects acquired from locking.
unlock(MutuallyExclusiveSetLock.LockState<T>) - Method in class com.palantir.util.MutuallyExclusiveSetLock
unmodifiableIterable() - Method in class com.palantir.common.collect.IterableView
 
unregisterMBeanCatchAndLogExceptions(String) - Static method in class com.palantir.util.JMXUtils
 
unwrap() - Method in interface com.palantir.util.result.Result
 
unwrapAndThrowAtlasDbDependencyException(Throwable) - Static method in class com.palantir.common.base.Throwables
If Throwable is a RuntimeException or Error, rethrow it.
unwrapErr() - Method in interface com.palantir.util.result.Result
 
unwrapIfPossible(Throwable) - Static method in class com.palantir.common.base.Throwables
 
update(Integer, T) - Method in class com.palantir.util.AggregatingVersionedMetric
 
update(Integer, T) - Method in class com.palantir.util.AggregatingVersionedSupplier
Insert, or replace, a (key, value) pair into the internal map.

V

value() - Method in interface com.palantir.util.VersionedType
 
valueOf(String) - Static method in enum com.palantir.async.initializer.AsyncInitializationState.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.common.compression.StreamCompression
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.common.proxy.CancelDelegate
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.exception.PalantirSqlException.DO_NOT_SET_INITIAL_SQL_EXCEPTION
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.exception.PalantirSqlException.SET_INITIAL_SQL_EXCEPTION
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.util.io.AvailabilityRequirement
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.util.JMXUtils.AllowConnections
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum com.palantir.util.PersistableBoolean
Returns the enum constant of this type with the specified name.
valueRef - Variable in class com.palantir.util.SoftCache.CacheEntry
 
values() - Static method in enum com.palantir.async.initializer.AsyncInitializationState.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.common.compression.StreamCompression
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.common.proxy.CancelDelegate
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.exception.PalantirSqlException.DO_NOT_SET_INITIAL_SQL_EXCEPTION
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.exception.PalantirSqlException.SET_INITIAL_SQL_EXCEPTION
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.util.io.AvailabilityRequirement
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.util.JMXUtils.AllowConnections
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum com.palantir.util.PersistableBoolean
Returns an array containing the constants of this enum type, in the order they are declared.
version() - Method in interface com.palantir.util.VersionedType
 
VersionedType<T> - Interface in com.palantir.util
 
visit(List<T>) - Method in class com.palantir.common.base.AbstractBatchingVisitable.ConsistentVisitor
 
visit(T) - Method in interface com.palantir.common.base.AbortingVisitor
Returns true if more items should be visited.
visit(T) - Method in interface com.palantir.common.visitor.Visitor
 
visit(T) - Method in interface com.palantir.common.visitor.VisitorCheckedException
 
visitOne(T) - Method in class com.palantir.common.base.AbstractBatchingVisitable.ConsistentVisitor
 
Visitor<T> - Interface in com.palantir.common.visitor
This redefines Visitor.visit(Object) to throw no checked exceptions.
VisitorCheckedException<T,​K extends Exception> - Interface in com.palantir.common.visitor
 
Visitors - Class in com.palantir.common.base
Useful methods for Visitor.
Visitors() - Constructor for class com.palantir.common.base.Visitors
 
visitWhile(Predicate<T>) - Method in class com.palantir.common.base.BatchingVisitableView
 
visitWhile(BatchingVisitable<T>, Predicate<T>) - Static method in class com.palantir.common.base.BatchingVisitables
Returns a visitable containing elements from the start of the visitable for which the predicate holds true.

W

waitForAvailability() - Method in class com.palantir.common.concurrent.BlockingWorkerPool
Waits until the number of tasks drops below the concurrent task limit.
waitForSubmittedTasks() - Method in class com.palantir.common.concurrent.BlockingWorkerPool
Waits for all tasks that have been previously submitted to the pool to finish.
withLhSide(T) - Method in class com.palantir.util.Pair
Return a new Pair with the left hand side set to the passed value.
withRhSide(T) - Method in class com.palantir.util.Pair
Returns a new Pair with the right hand side set to the passed value.
wrap(BatchingVisitable<S>) - Static method in class com.palantir.common.base.BatchingVisitables
This will wrap the passed visitor and return a more generic type.
wrap(VisitorCheckedException<? super T, ? extends K>) - Static method in class com.palantir.common.base.AbortingVisitors
Since a visitor is purely a consumer of values, it can be cast to a more specific type.
wrap(Iterable<? extends T>) - Static method in class com.palantir.common.collect.IterableUtils
This can be safely used to cast an Iterable from one type to a super type.
wrap(Iterator<? extends T>) - Static method in class com.palantir.common.base.ClosableIterators
Deprecated.
Use the explicit `wrapWithEmptyClose` instead. This helps avoid accidental unwrapping.
wrap(Iterator<? extends T>) - Static method in class com.palantir.common.collect.IteratorUtils
 
wrap(Iterator<? extends T>, Closeable) - Static method in class com.palantir.common.base.ClosableIterators
 
wrapBatching(AbortingVisitor<? super List<F>, ? extends K>) - Static method in class com.palantir.common.base.AbortingVisitors
Since a visitor is purely a consumer of values, it can be cast to a more specific type.
wrapWithEmptyClose(Iterator<? extends T>) - Static method in class com.palantir.common.base.ClosableIterators
 
write(byte[], int, int) - Method in class com.palantir.util.ByteArrayIOStream
 
write(int) - Method in class com.palantir.util.ByteArrayIOStream
 

Y

YES - com.palantir.exception.PalantirSqlException.DO_NOT_SET_INITIAL_SQL_EXCEPTION
 
YES - com.palantir.exception.PalantirSqlException.SET_INITIAL_SQL_EXCEPTION
 

Z

zip(Iterable<? extends T>, Function<T, U>) - Static method in class com.palantir.common.collect.IterableUtils
 
zip(Iterable<? extends T>, Iterable<? extends U>) - Static method in class com.palantir.common.collect.IterableUtils
 
zip(Iterator<? extends T>, Iterator<? extends U>) - Static method in class com.palantir.common.collect.IteratorUtils
 
A B C D E F G H I J K L M N O P Q R S T U V W Y Z 
All Classes All Packages