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

A

ABFS_CLIENT_ENDPOINT - Static variable in class alluxio.conf.PropertyKey
 
ABFS_CLIENT_ENDPOINT - Static variable in class alluxio.conf.PropertyKey.Name
 
ABFS_CLIENT_ID - Static variable in class alluxio.conf.PropertyKey
 
ABFS_CLIENT_ID - Static variable in class alluxio.conf.PropertyKey.Name
 
ABFS_CLIENT_SECRET - Static variable in class alluxio.conf.PropertyKey
 
ABFS_CLIENT_SECRET - Static variable in class alluxio.conf.PropertyKey.Name
 
ABFS_MSI_ENDPOINT - Static variable in class alluxio.conf.PropertyKey
 
ABFS_MSI_ENDPOINT - Static variable in class alluxio.conf.PropertyKey.Name
 
ABFS_MSI_TENANT - Static variable in class alluxio.conf.PropertyKey
 
ABFS_MSI_TENANT - Static variable in class alluxio.conf.PropertyKey.Name
 
abort() - Method in class alluxio.security.login.AlluxioLoginModule
Aborts the authentication (second phase).
abort() - Method in class alluxio.security.login.AppLoginModule
Aborts the authentication (second phase).
abortBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Aborts a temporary block.
abortBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Aborts the temporary block created by the session.
AbortedException - Exception in alluxio.exception.status
Exception indicating that the operation was aborted, typically due to a concurrency issue like sequencer check failures, transaction aborts, etc.
AbortedException(String) - Constructor for exception alluxio.exception.status.AbortedException
 
AbortedException(String, Throwable) - Constructor for exception alluxio.exception.status.AbortedException
 
AbortedException(Throwable) - Constructor for exception alluxio.exception.status.AbortedException
 
abortMultiPartUpload() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
abortMultiPartUploadInternal() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
AbstractClient - Class in alluxio
AbstractClient is the base class for all the grpc clients in alluxio.
AbstractClient(ClientContext) - Constructor for class alluxio.AbstractClient
Creates a new client base with default retry policy supplier.
AbstractClient(ClientContext, Supplier<RetryPolicy>) - Constructor for class alluxio.AbstractClient
Creates a new client base with specified retry policy supplier.
AbstractClient.RpcCallable<V> - Interface in alluxio
AbstractExtendedAttribute<T> - Class in alluxio.master.file.meta.xattr
Extend this class to implement any extended attributes.
AbstractJobMasterClient - Class in alluxio
The base class for job master clients.
AbstractJobMasterClient(MasterClientContext) - Constructor for class alluxio.AbstractJobMasterClient
Creates a new master client base.
AbstractJobMasterClient(MasterClientContext, Supplier<RetryPolicy>) - Constructor for class alluxio.AbstractJobMasterClient
Creates a new master client base.
AbstractMasterClient - Class in alluxio
The base class for master clients.
AbstractMasterClient(MasterClientContext) - Constructor for class alluxio.AbstractMasterClient
Creates a new master client base and default the selection policy to primary master.
AbstractMasterClient(MasterClientContext, MasterSelectionPolicy) - Constructor for class alluxio.AbstractMasterClient
Creates a new master client base.
AbstractMasterClient(MasterClientContext, Supplier<RetryPolicy>) - Constructor for class alluxio.AbstractMasterClient
Creates a new master client without a specific address.
AbstractMasterSelectionPolicy - Class in alluxio.master.selectionpolicy
Base class of master selection policy that determines which master node a client should connect to.
AbstractMasterSelectionPolicy() - Constructor for class alluxio.master.selectionpolicy.AbstractMasterSelectionPolicy
 
AbstractSaslClientHandler - Class in alluxio.security.authentication
Abstract SaslClientHandler implementation that maintains SaslClient instance.
AbstractSaslClientHandler(ChannelAuthenticationScheme) - Constructor for class alluxio.security.authentication.AbstractSaslClientHandler
Creates an abstract sasl handler for given scheme.
AbstractSaslServerHandler - Class in alluxio.security.authentication
Abstract SaslServerHandler implementation that maintains SaslServer instance.
AbstractSaslServerHandler() - Constructor for class alluxio.security.authentication.AbstractSaslServerHandler
 
AbstractShell - Class in alluxio.cli
Abstract class for handling command line inputs.
AbstractShell(Map<String, String[]>, Set<String>, AlluxioConfiguration) - Constructor for class alluxio.cli.AbstractShell
Creates a new instance of AbstractShell.
AbstractValidationTask - Class in alluxio.cli
Abstract class for validation environment.
AbstractValidationTask() - Constructor for class alluxio.cli.AbstractValidationTask
 
acceptEither(CompletionStage<? extends T>, Consumer<? super T>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
acceptEither(CompletionStage<? extends T>, Consumer<? super T>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when either this or the other given stage complete normally, is executed with the corresponding result as argument to the supplied action.
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when either this or the other given stage complete normally, is executed using this stage's default asynchronous execution facility, with the corresponding result as argument to the supplied action.
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
acceptEitherAsync(CompletionStage<? extends T>, Consumer<? super T>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when either this or the other given stage complete normally, is executed using the supplied executor, with the corresponding result as argument to the supplied action.
acceptMessage(Object) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
 
accessBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Notifies the block store that a block was accessed so the block store could update accordingly the registered listeners such as evictor and allocator on block access.
accessBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Access the block for a given session.
AccessControlException - Exception in alluxio.exception
Thrown when permission checking fails.
AccessControlException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.AccessControlException
Constructs a new exception with the specified exception message and multiple parameters.
AccessControlException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.AccessControlException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
AccessControlException(String) - Constructor for exception alluxio.exception.AccessControlException
Constructs a new exception with the specified detail message.
AccessControlException(String, Throwable) - Constructor for exception alluxio.exception.AccessControlException
Constructs a new exception with the specified detail message and cause.
AccessControlList - Class in alluxio.security.authorization
Access control list for a file or directory.
AccessControlList() - Constructor for class alluxio.security.authorization.AccessControlList
Creates a new instance where owning user and owning group are initialized to empty strings, and no action is permitted for any user or group.
AccessControlList.AccessControlListDeserializer - Class in alluxio.security.authorization
This is a custom json deserializer for AccessControlList class.
AccessControlList.AccessControlListSerializer - Class in alluxio.security.authorization
This is a custom json serializer for AccessControlList class.
AccessControlListDeserializer() - Constructor for class alluxio.security.authorization.AccessControlList.AccessControlListDeserializer
Creates a AccessControlListDeserializer.
AccessControlListSerializer() - Constructor for class alluxio.security.authorization.AccessControlList.AccessControlListSerializer
Creates a AccessControlListSerializer.
ACL - alluxio.underfs.Fingerprint.Tag
 
AclAction - Enum in alluxio.security.authorization
Actions to be controlled in AccessControlList.
AclActions - Class in alluxio.security.authorization
Permitted actions of an entry in AccessControlList.
AclActions() - Constructor for class alluxio.security.authorization.AclActions
Creates a new instance where no action is permitted.
AclActions(AclActions) - Constructor for class alluxio.security.authorization.AclActions
Creates a copy of actions.
AclActions(Set<AclAction>) - Constructor for class alluxio.security.authorization.AclActions
Creats a new instance with initial permitted actions.
AclEntry - Class in alluxio.security.authorization
An entry in AccessControlList.
AclEntry.Builder - Class in alluxio.security.authorization
Builder for AclEntry.
AclEntryType - Enum in alluxio.security.authorization
Types of entries in AccessControlList.
acquire() - Method in class alluxio.resource.DynamicResourcePool
Acquires a resource of type {code T} from the pool.
acquire() - Method in interface alluxio.resource.Pool
Acquires a resource from the pool.
acquire() - Method in class alluxio.resource.ResourcePool
Acquires an object of type T from the pool.
acquire(int) - Static method in class alluxio.network.protocol.databuffer.NioDirectBufferPool
 
acquire(long, TimeUnit) - Method in class alluxio.resource.DynamicResourcePool
Acquires a resource of type {code T} from the pool.
acquire(long, TimeUnit) - Method in interface alluxio.resource.Pool
Acquires a resource from the pool.
acquire(long, TimeUnit) - Method in class alluxio.resource.ResourcePool
Acquires an object of type {code T} from the pool.
acquireChannel(GrpcNetworkGroup, GrpcServerAddress, AlluxioConfiguration) - Method in class alluxio.grpc.GrpcChannelPool
Acquires and increases the ref-count for the ManagedChannel.
acquireCloseable() - Method in interface alluxio.resource.Pool
Acquires a resource wrapped inside a PooledResource, which will release the resource to this pool when it's closed.
acquireCloseable(long, TimeUnit) - Method in interface alluxio.resource.Pool
Acquires a resource wrapped inside a PooledResource, which will release the resource to this pool when it's closed.
acquireUfsResource() - Method in class alluxio.underfs.UfsManager.UfsClient
 
adapt(Runnable) - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns a new ForkJoinTask that performs the run method of the given Runnable as its action, and returns a null result upon ForkJoinTask.join().
adapt(Runnable, T) - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns a new ForkJoinTask that performs the run method of the given Runnable as its action, and returns the given result upon ForkJoinTask.join().
adapt(Callable<? extends T>) - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns a new ForkJoinTask that performs the call method of the given Callable as its action, and returns its result upon ForkJoinTask.join(), translating any checked exceptions encountered into RuntimeException.
add(int, T) - Method in class alluxio.collections.UnmodifiableArrayList
 
add(long, T) - Method in class alluxio.util.executor.ControllableQueue
Adds a new node into the queue.
add(AclAction) - Method in class alluxio.security.authorization.AclActions
Adds a permitted action.
add(T) - Method in class alluxio.collections.ConcurrentHashSet
 
add(T) - Method in class alluxio.collections.DelegatingSet
 
add(T) - Method in interface alluxio.collections.FieldIndex
Adds an object o to the index.
add(T) - Method in class alluxio.collections.IndexedSet
Adds an object o to the set if there is no other object o2 such that (o == null ? o2 == null : o.equals(o2)).
add(T) - Method in class alluxio.collections.NonUniqueFieldIndex
 
add(T) - Method in class alluxio.collections.UniqueFieldIndex
 
add(T) - Method in class alluxio.collections.UnmodifiableArrayList
 
add(T) - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Adds a new input to be operated on.
add(T, List<T>) - Method in class alluxio.collections.DirectedAcyclicGraph
Adds a node to the DAG, that takes the given payload and depends on the specified parents.
ADD_EXISTING_BLOCK - alluxio.exception.ExceptionMessage
 
addAction(AclAction) - Method in class alluxio.security.authorization.AclEntry.Builder
Adds a permitted action.
addAll(int, Collection<? extends T>) - Method in class alluxio.collections.UnmodifiableArrayList
 
addAll(Collection<? extends T>) - Method in class alluxio.collections.DelegatingSet
 
addAll(Collection<? extends T>) - Method in class alluxio.collections.UnmodifiableArrayList
 
addBlock(String, long, long, long) - Method in class alluxio.util.webui.UIFileInfo
Adds a block to the file information.
addBlockMeta(BlockMeta) - Method in interface alluxio.worker.block.meta.StorageDir
Adds the metadata of a new block into this storage dir.
addBuffersToStream(ByteBuf[], OutputStream) - Static method in class alluxio.grpc.GrpcSerializationUtils
Add the given buffers directly to the gRPC output stream.
addChild(DirectedAcyclicGraphNode<T>) - Method in class alluxio.collections.DirectedAcyclicGraphNode
Adds a child node to the node.
addClusterProperty(String, Object, Source) - Method in class alluxio.wire.Configuration.Builder
Adds a cluster level property.
addIfAbsent(T) - Method in class alluxio.collections.ConcurrentHashSet
Adds an element into the set, if and only if it is not already a part of the set.
addIfTrue(boolean, List<String>, String) - Static method in class alluxio.check.UpdateCheck
Add feature name if condition is true.
addInnerValue(K1, K2, V) - Method in class alluxio.collections.TwoKeyConcurrentMap
 
addMount(long, AlluxioURI, UnderFileSystemConfiguration) - Method in interface alluxio.underfs.UfsManager
Keeps track of a mount id and maps it to its URI in Alluxio and configuration.
addMountWithRecorder(long, AlluxioURI, UnderFileSystemConfiguration, Recorder) - Method in interface alluxio.underfs.UfsManager
Keeps track of a mount id and maps it to its URI in Alluxio and configuration and records the execution process.
addParent(DirectedAcyclicGraphNode<T>) - Method in class alluxio.collections.DirectedAcyclicGraphNode
Adds a parent node to the node.
addPathProperty(String, String, String) - Method in class alluxio.wire.Configuration.Builder
Adds a path level property.
addReference() - Method in class alluxio.concurrent.ClientRWLock
Increments the reference count.
Address - Class in alluxio.wire
The address of a node.
Address() - Constructor for class alluxio.wire.Address
Creates a new instance of Address.
Address(NetAddress) - Constructor for class alluxio.wire.Address
Creates a new instance of Address from proto representation.
Address(String, int) - Constructor for class alluxio.wire.Address
Creates a new instance of Address.
addService(GrpcService) - Method in class alluxio.grpc.GrpcServerBuilder
Add a service to this server.
addService(ServiceType, GrpcService) - Method in class alluxio.grpc.GrpcServerBuilder
Add a service to this server.
addTag(String, String) - Method in class alluxio.metrics.Metric
Adds a new tag.
addTempBlockMeta(TempBlockMeta) - Method in interface alluxio.worker.block.meta.StorageDir
Adds the metadata of a new block into this storage dir.
addTimer(ScheduledTimer) - Static method in class alluxio.heartbeat.HeartbeatScheduler
 
addToPendingCount(int) - Method in class alluxio.concurrent.jsr.CountedCompleter
Adds (atomically) the given value to the pending count.
addUserAgentEnvironments(List<String>) - Static method in class alluxio.check.UpdateCheck
Adds the information of user environment to given list.
addUserAgentFeatures(List<String>) - Static method in class alluxio.check.UpdateCheck
Get the feature's information.
addValue(double) - Method in class alluxio.metrics.Metric
Add metric value delta to the existing value.
afterConnect() - Method in class alluxio.AbstractClient
This method is called after the connection is made to the remote.
afterDisconnect() - Method in class alluxio.AbstractClient
This method is called after the connection is disconnected.
afterDisconnect() - Method in class alluxio.AbstractMasterClient
 
AggregateException - Exception in alluxio.exception
Represents a collection of exceptions.
AggregateException(Collection<Exception>) - Constructor for exception alluxio.exception.AggregateException
Creates a new instance of AggregateException.
ALL - alluxio.file.options.DescendantType
Process all descendants.
ALL - alluxio.security.authorization.Mode.Bits
 
allMetricKeys() - Static method in class alluxio.metrics.MetricKey
 
allMetrics() - Static method in class alluxio.metrics.MetricsSystem
 
allocate(int) - Static method in class alluxio.network.protocol.databuffer.PooledDirectNioByteBuf
Allocates a new buffer from NioDirectBufferPool.
AllocateOptions - Class in alluxio.worker.block
Used to specify various options while allocating space.
allOf(CompletableFuture<?>...) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is completed when all of the given CompletableFutures complete.
allShouldReportMetricKeys(MetricsSystem.InstanceType) - Static method in class alluxio.metrics.MetricKey
Gets all the metric keys that belong to the given instance type and should be reported.
alluxio - package alluxio
 
ALLUXIO_2X_UPGRADE_DOC_URL - Static variable in class alluxio.RuntimeConstants
The URL of Alluxio 1.x to 2.x upgrade documentation.
ALLUXIO_CLI_PATH - Static variable in class alluxio.Constants
 
ALLUXIO_DEBUG_DOCS_URL - Static variable in class alluxio.RuntimeConstants
The URL of Alluxio debugging documentation.
ALLUXIO_DOCS_URL - Static variable in class alluxio.RuntimeConstants
The URL of Alluxio documentation for this version on project web site.
ALLUXIO_JAR - Static variable in class alluxio.RuntimeConstants
The relative path to the Alluxio target jar.
ALLUXIO_JAVADOC_URL - Static variable in class alluxio.RuntimeConstants
The URL of Alluxio javadoc documentation.
ALLUXIO_LOCALITY_SCRIPT - Static variable in class alluxio.Constants
 
ALLUXIO_SECURITY_DOCS_URL - Static variable in class alluxio.RuntimeConstants
The URL of Alluxio security documentation.
alluxio.annotation - package alluxio.annotation
 
alluxio.check - package alluxio.check
 
alluxio.cli - package alluxio.cli
 
alluxio.client - package alluxio.client
 
alluxio.client.file - package alluxio.client.file
 
alluxio.client.file.cache - package alluxio.client.file.cache
 
alluxio.client.file.cache.store - package alluxio.client.file.cache.store
 
alluxio.client.hive - package alluxio.client.hive
 
alluxio.client.quota - package alluxio.client.quota
 
alluxio.clock - package alluxio.clock
 
alluxio.collections - package alluxio.collections
 
alluxio.concurrent - package alluxio.concurrent
 
alluxio.concurrent.jsr - package alluxio.concurrent.jsr
 
alluxio.conf - package alluxio.conf
 
alluxio.conf.path - package alluxio.conf.path
 
alluxio.exception - package alluxio.exception
 
alluxio.exception.runtime - package alluxio.exception.runtime
 
alluxio.exception.status - package alluxio.exception.status
 
alluxio.executor - package alluxio.executor
 
alluxio.extensions - package alluxio.extensions
 
alluxio.file - package alluxio.file
 
alluxio.file.options - package alluxio.file.options
 
alluxio.grpc - package alluxio.grpc
 
alluxio.heartbeat - package alluxio.heartbeat
 
alluxio.job - package alluxio.job
 
alluxio.master - package alluxio.master
 
alluxio.master.block - package alluxio.master.block
 
alluxio.master.file - package alluxio.master.file
 
alluxio.master.file.meta - package alluxio.master.file.meta
 
alluxio.master.file.meta.xattr - package alluxio.master.file.meta.xattr
 
alluxio.master.journal - package alluxio.master.journal
 
alluxio.master.metastore - package alluxio.master.metastore
 
alluxio.master.metastore.rocks - package alluxio.master.metastore.rocks
 
alluxio.master.selectionpolicy - package alluxio.master.selectionpolicy
 
alluxio.metrics - package alluxio.metrics
 
alluxio.metrics.aggregator - package alluxio.metrics.aggregator
 
alluxio.metrics.sink - package alluxio.metrics.sink
 
alluxio.metrics.source - package alluxio.metrics.source
 
alluxio.network - package alluxio.network
 
alluxio.network.netty - package alluxio.network.netty
 
alluxio.network.protocol - package alluxio.network.protocol
 
alluxio.network.protocol.databuffer - package alluxio.network.protocol.databuffer
 
alluxio.recorder - package alluxio.recorder
 
alluxio.refresh - package alluxio.refresh
 
alluxio.resource - package alluxio.resource
 
alluxio.retry - package alluxio.retry
Set of utilities for working with retryable operations.
alluxio.security - package alluxio.security
 
alluxio.security.authentication - package alluxio.security.authentication
 
alluxio.security.authentication.plain - package alluxio.security.authentication.plain
 
alluxio.security.authorization - package alluxio.security.authorization
 
alluxio.security.group - package alluxio.security.group
 
alluxio.security.group.provider - package alluxio.security.group.provider
 
alluxio.security.login - package alluxio.security.login
 
alluxio.security.user - package alluxio.security.user
 
alluxio.shell - package alluxio.shell
 
alluxio.thread - package alluxio.thread
 
alluxio.time - package alluxio.time
 
alluxio.underfs - package alluxio.underfs
 
alluxio.underfs.options - package alluxio.underfs.options
 
alluxio.uri - package alluxio.uri
 
alluxio.util - package alluxio.util
 
alluxio.util.executor - package alluxio.util.executor
 
alluxio.util.interfaces - package alluxio.util.interfaces
 
alluxio.util.io - package alluxio.util.io
 
alluxio.util.logging - package alluxio.util.logging
 
alluxio.util.network - package alluxio.util.network
 
alluxio.util.network.tls - package alluxio.util.network.tls
 
alluxio.util.proto - package alluxio.util.proto
 
alluxio.util.webui - package alluxio.util.webui
 
alluxio.wire - package alluxio.wire
 
alluxio.worker - package alluxio.worker
 
alluxio.worker.block - package alluxio.worker.block
 
alluxio.worker.block.io - package alluxio.worker.block.io
 
alluxio.worker.block.management - package alluxio.worker.block.management
 
alluxio.worker.block.meta - package alluxio.worker.block.meta
 
alluxio.worker.dora - package alluxio.worker.dora
 
AlluxioConfiguration - Interface in alluxio.conf
Alluxio configuration.
AlluxioException - Exception in alluxio.exception
General AlluxioException used throughout the system.
AlluxioException(String) - Constructor for exception alluxio.exception.AlluxioException
Constructs an AlluxioException with the given message.
AlluxioException(String, Throwable) - Constructor for exception alluxio.exception.AlluxioException
Constructs an AlluxioException with the given message and cause.
AlluxioException(Throwable) - Constructor for exception alluxio.exception.AlluxioException
Constructs an AlluxioException with the given cause.
AlluxioForkJoinWorkerThreadFactory(String, boolean) - Constructor for class alluxio.concurrent.jsr.ForkJoinPool.AlluxioForkJoinWorkerThreadFactory
Creates a new thread-factory for ForkJoinPool.
AlluxioJobMasterInfo - Class in alluxio.wire
Alluxio job master information.
AlluxioJobMasterInfo() - Constructor for class alluxio.wire.AlluxioJobMasterInfo
Creates a new instance of AlluxioJobMasterInfo.
AlluxioJobWorkerInfo - Class in alluxio.wire
Alluxio job worker information.
AlluxioJobWorkerInfo() - Constructor for class alluxio.wire.AlluxioJobWorkerInfo
Creates a new instance of AlluxioJobWorkerInfo.
AlluxioLoginModule - Class in alluxio.security.login
A login module that search the Kerberos or OS user from Subject, and then convert to an Alluxio user.
AlluxioLoginModule() - Constructor for class alluxio.security.login.AlluxioLoginModule
Constructs a new AlluxioLoginModule.
AlluxioMasterInfo - Class in alluxio.wire
Alluxio master information.
AlluxioMasterInfo() - Constructor for class alluxio.wire.AlluxioMasterInfo
Creates a new instance of AlluxioMasterInfo.
AlluxioProperties - Class in alluxio.conf
Provides the source of truth of property values and a unified abstraction to put and get properties, hiding the difference of accessing user-specified properties, the default properties (known at construction time) and the extension properties (known at runtime).
AlluxioProperties() - Constructor for class alluxio.conf.AlluxioProperties
Constructs a new instance of Alluxio properties.
AlluxioProperties(AlluxioProperties) - Constructor for class alluxio.conf.AlluxioProperties
 
AlluxioProxyInfo - Class in alluxio.wire
Alluxio proxy information.
AlluxioProxyInfo() - Constructor for class alluxio.wire.AlluxioProxyInfo
Creates a new instance of AlluxioProxyInfo.
AlluxioResourceLeakDetector<T> - Class in alluxio.resource
An extension of the ResourceLeakDetector with custom error messages for use in the Alluxio codebase.
AlluxioResourceLeakDetector(Class<?>, int, boolean) - Constructor for class alluxio.resource.AlluxioResourceLeakDetector
Creates a new instance of the leak detector with the specific resource type and sampling interval.
AlluxioResourceLeakDetectorFactory - Class in alluxio.resource
The class responsible for instantiating AlluxioResourceLeakDetector.
AlluxioResourceLeakDetectorFactory() - Constructor for class alluxio.resource.AlluxioResourceLeakDetectorFactory
 
AlluxioRuntimeException - Exception in alluxio.exception.runtime
Alluxio RuntimeException.
AlluxioRuntimeException(Status, String, Throwable, ErrorType, boolean, Any...) - Constructor for exception alluxio.exception.runtime.AlluxioRuntimeException
 
AlluxioStatusException - Exception in alluxio.exception.status
An exception thrown by Alluxio.
AlluxioStatusException(Status) - Constructor for exception alluxio.exception.status.AlluxioStatusException
 
AlluxioStorageType - Enum in alluxio.client
Specifies the type of data interaction with Alluxio.
AlluxioURI - Class in alluxio
This class represents a URI in the Alluxio system.
AlluxioURI(AlluxioURI, AlluxioURI) - Constructor for class alluxio.AlluxioURI
Resolves a child AlluxioURI against a parent AlluxioURI.
AlluxioURI(AlluxioURI, String, boolean) - Constructor for class alluxio.AlluxioURI
Constructs an AlluxioURI from a base URI and a new path component.
AlluxioURI(String) - Constructor for class alluxio.AlluxioURI
Constructs an AlluxioURI from a String.
AlluxioURI(String, Authority, String) - Constructor for class alluxio.AlluxioURI
Constructs an AlluxioURI from components.
AlluxioURI(String, Authority, String, Map<String, String>) - Constructor for class alluxio.AlluxioURI
Constructs an AlluxioURI from components.
AlluxioWorkerInfo - Class in alluxio.wire
Alluxio worker information.
AlluxioWorkerInfo() - Constructor for class alluxio.wire.AlluxioWorkerInfo
Creates a new instance of AlluxioWorkerInfo.
AlreadyExistsException - Exception in alluxio.exception.status
Exception indicating that an attempt to create an entity failed because one already exists.
AlreadyExistsException(String) - Constructor for exception alluxio.exception.status.AlreadyExistsException
 
AlreadyExistsException(String, Throwable) - Constructor for exception alluxio.exception.status.AlreadyExistsException
 
AlreadyExistsException(Throwable) - Constructor for exception alluxio.exception.status.AlreadyExistsException
 
AlreadyExistsRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that an attempt to create an entity failed because one already exists.
AlreadyExistsRuntimeException(String) - Constructor for exception alluxio.exception.runtime.AlreadyExistsRuntimeException
Constructor.
AlreadyExistsRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.AlreadyExistsRuntimeException
Constructor.
ALWAYS - alluxio.wire.LoadMetadataType
Always load metadata when listing status on a directory.
and(Mode.Bits) - Method in enum alluxio.security.authorization.Mode.Bits
 
and(Mode, Mode) - Static method in class alluxio.security.authorization.Mode
 
ANSI_BLACK - Static variable in class alluxio.Constants
 
ANSI_BLUE - Static variable in class alluxio.Constants
 
ANSI_CYAN - Static variable in class alluxio.Constants
 
ANSI_GREEN - Static variable in class alluxio.Constants
 
ANSI_PURPLE - Static variable in class alluxio.Constants
 
ANSI_RED - Static variable in class alluxio.Constants
 
ANSI_RESET - Static variable in class alluxio.Constants
 
ANSI_WHITE - Static variable in class alluxio.Constants
 
ANSI_YELLOW - Static variable in class alluxio.Constants
 
ANY - alluxio.worker.block.management.BackoffStrategy
 
ANY_TIER - Static variable in class alluxio.worker.block.BlockStoreLocation
Special value to indicate any tier.
anyDirInAnyTierWithMedium(String) - Static method in class alluxio.worker.block.BlockStoreLocation
Convenience method to return the block store location representing any dir in any tier with specific medium.
anyDirInTier(String) - Static method in class alluxio.worker.block.BlockStoreLocation
Convenience method to return the block store location representing any dir in the tier.
anyMaster() - Static method in class alluxio.master.selectionpolicy.MasterSelectionPolicy.Factory
Creates a MasterSelectionPolicy that selects a random master to connect.
anyOf(CompletableFuture<?>...) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is completed when any of the given CompletableFutures complete, with the same result.
anyStandbyMaster() - Static method in class alluxio.master.selectionpolicy.MasterSelectionPolicy.Factory
Creates a MasterSelectionPolicy that selects a standby master to connect.
anyStandbyMaster(long) - Static method in class alluxio.master.selectionpolicy.MasterSelectionPolicy.Factory
Creates a MasterSelectionPolicy that selects a standby master to connect.
anyTier() - Static method in class alluxio.worker.block.BlockStoreLocation
Convenience method to return the block store location representing any dir in any tier.
AppCallbackHandler(String) - Constructor for class alluxio.security.login.AppLoginModule.AppCallbackHandler
Creates a new instance of AppLoginModule.AppCallbackHandler.
append(DataBuffer) - Method in class alluxio.worker.block.io.BlockWriter
Appends buffer.readableBytes() bytes to the end of this block writer from the given buffer.
append(DataBuffer) - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
append(ByteBuf) - Method in class alluxio.worker.block.io.BlockWriter
Appends buf.readableBytes() bytes to the end of this block writer from the given buf.
append(ByteBuf) - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
append(ByteBuffer) - Method in class alluxio.worker.block.io.BlockWriter
Appends data to the end of a block from an input ByteBuffer.
append(ByteBuffer) - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
appendPath(URI, String) - Static method in class alluxio.util.URIUtils
Appends the given path to the given base URI.
appendPathOrDie(URI, String) - Static method in class alluxio.util.URIUtils
Appends the given path to the given base URI.
AppLoginModule - Class in alluxio.security.login
An app login module that creates a user based on the user name provided through application configuration.
AppLoginModule() - Constructor for class alluxio.security.login.AppLoginModule
Constructs a new AppLoginModule.
AppLoginModule.AppCallbackHandler - Class in alluxio.security.login
A callback handler for AppLoginModule.
apply() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectStoreOperation
Applies this operation.
apply(A, B, C) - Method in interface alluxio.collections.TwoKeyConcurrentMap.TriFunction
 
applyDirectoryUMask(Mode, String) - Static method in class alluxio.util.ModeUtils
Applies the default umask for newly created directories to this mode.
applyFileUMask(Mode, String) - Static method in class alluxio.util.ModeUtils
Applies the default umask for newly created files to this mode.
applyToEither(CompletionStage<? extends T>, Function<? super T, U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
applyToEither(CompletionStage<? extends T>, Function<? super T, U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when either this or the other given stage complete normally, is executed with the corresponding result as argument to the supplied function.
applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when either this or the other given stage complete normally, is executed using this stage's default asynchronous execution facility, with the corresponding result as argument to the supplied function.
applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
applyToEitherAsync(CompletionStage<? extends T>, Function<? super T, U>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when either this or the other given stage complete normally, is executed using the supplied executor, with the corresponding result as argument to the supplied function.
approximateContentHash(long, long) - Static method in class alluxio.util.UnderFileSystemUtils
Returns an approximate content hash, using the length and modification time.
argsToString(String, T...) - Static method in class alluxio.util.CommonUtils
Converts varargs of objects to a string.
ARRAY_BLOCKING_QUEUE - alluxio.executor.ThreadPoolExecutorQueueType
LinkedBlockingQueue.
asAsyncCacheRequest() - Method in class alluxio.util.proto.ProtoMessage
 
asLocalBlockCloseRequest() - Method in class alluxio.util.proto.ProtoMessage
Gets the local block close request or throws runtime exception if mMessage is not of type Protocol.LocalBlockCloseRequest.
asLocalBlockCompleteRequest() - Method in class alluxio.util.proto.ProtoMessage
 
asLocalBlockCreateRequest() - Method in class alluxio.util.proto.ProtoMessage
 
asLocalBlockCreateResponse() - Method in class alluxio.util.proto.ProtoMessage
 
asLocalBlockOpenRequest() - Method in class alluxio.util.proto.ProtoMessage
Gets the local block open request or throws runtime exception if mMessage is not of type Protocol.LocalBlockOpenRequest.
asLocalBlockOpenResponse() - Method in class alluxio.util.proto.ProtoMessage
Gets the local block open response or throws runtime exception if mMessage is not of type Protocol.LocalBlockOpenResponse.
asPlainText(Throwable) - Static method in class alluxio.util.ExceptionUtils
Prints the stacktrace to a string.
asReadRequest() - Method in class alluxio.util.proto.ProtoMessage
Gets the read request or throws runtime exception if mMessage is not of type Protocol.ReadRequest.
asReadResponse() - Method in class alluxio.util.proto.ProtoMessage
Gets the read response or throws runtime exception if mMessage is not of type Protocol.ReadResponse.
asResponse() - Method in class alluxio.util.proto.ProtoMessage
Gets the response or throws runtime exception if mMessage is not of type Protocol.Response.
assertValidPort(int) - Static method in class alluxio.util.network.NetworkAddressUtils
Checks if the given port is valid.
asWriteRequest() - Method in class alluxio.util.proto.ProtoMessage
Gets the write request or throws runtime exception if mMessage is not of type Protocol.WriteRequest.
ASYNC_PERSIST - alluxio.client.UnderStorageType
Persist data to the under storage asynchronously.
ASYNC_THROUGH - alluxio.client.WriteType
[Experimental] Write the file asynchronously to the under fs.
asyncCache(AsyncCacheRequest) - Method in interface alluxio.worker.block.BlockWorker
Deprecated.
This method will be deprecated as of v3.0, use BlockWorker.cache(alluxio.grpc.CacheRequest)
AtomicFileOutputStream - Class in alluxio.underfs
A AtomicFileOutputStream writes to a temporary file and renames on close.
AtomicFileOutputStream(String, AtomicFileOutputStreamCallback, CreateOptions) - Constructor for class alluxio.underfs.AtomicFileOutputStream
Constructs a new AtomicFileOutputStream.
AtomicFileOutputStreamCallback - Interface in alluxio.underfs
A AtomicFileOutputStreamCallback is the callback interface used when using a AtomicFileOutputStream.
attempt() - Method in interface alluxio.refresh.RefreshPolicy
Checks if it is time to perform the next refresh and returns immediately.
attempt() - Method in class alluxio.refresh.TimeoutRefresh
 
attempt() - Method in class alluxio.retry.CountingRetry
 
attempt() - Method in interface alluxio.retry.RetryPolicy
Waits until it is time to perform the next retry, then returns.
attempt() - Method in class alluxio.retry.SleepingRetry
 
attempt() - Method in class alluxio.retry.TimeBoundedRetry
 
attempt() - Method in class alluxio.retry.TimeoutRetry
 
authenticate(AuthType, Subject, AlluxioConfiguration) - Method in class alluxio.grpc.GrpcChannel
 
authenticate(StreamObserver<SaslMessage>) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
authenticate(String, String) - Method in interface alluxio.security.authentication.AuthenticationProvider
The authenticate method is called by the PlainSaslServerCallbackHandler in the PlainSaslServer layer to authenticate users for their requests.
authenticate(String, String) - Method in class alluxio.security.authentication.ImpersonationAuthenticator
 
authenticate(String, String) - Method in class alluxio.security.authentication.plain.CustomAuthenticationProvider
 
authenticate(String, String) - Method in class alluxio.security.authentication.plain.SimpleAuthenticationProvider
 
AuthenticatedChannelClientDriver - Class in alluxio.security.authentication
Responsible for driving authentication traffic from client-side.
AuthenticatedChannelClientDriver(SaslClientHandler, GrpcChannelKey) - Constructor for class alluxio.security.authentication.AuthenticatedChannelClientDriver
Creates client driver with given handshake handler.
AuthenticatedChannelServerDriver - Class in alluxio.security.authentication
Responsible for driving authentication traffic from server-side.
AuthenticatedChannelServerDriver(AuthenticationServer) - Constructor for class alluxio.security.authentication.AuthenticatedChannelServerDriver
AuthenticatedClientUser - Class in alluxio.security.authentication
An instance of this class represents a client user connecting to PlainSaslServer.
AuthenticatedUserInfo - Class in alluxio.security.authentication
Used to define an authenticated user.
AuthenticatedUserInfo() - Constructor for class alluxio.security.authentication.AuthenticatedUserInfo
Creates an AuthenticatedUserInfo instance.
AuthenticatedUserInfo(String) - Constructor for class alluxio.security.authentication.AuthenticatedUserInfo
Creates an AuthenticatedUserInfo instance.
AuthenticatedUserInfo(String, String) - Constructor for class alluxio.security.authentication.AuthenticatedUserInfo
Creates an AuthenticatedUserInfo instance.
AuthenticatedUserInfo(String, String, String) - Constructor for class alluxio.security.authentication.AuthenticatedUserInfo
Creates an AuthenticatedUserInfo instance.
AuthenticatedUserInjector - Class in alluxio.security.authentication
Server side interceptor for setting authenticated user in AuthenticatedClientUser.
AuthenticatedUserInjector(AuthenticationServer) - Constructor for class alluxio.security.authentication.AuthenticatedUserInjector
Creates AuthenticationServer with given authentication server.
AUTHENTICATION_INACTIVE_CHANNEL_REAUTHENTICATE_PERIOD - Static variable in class alluxio.conf.PropertyKey
 
AUTHENTICATION_INACTIVE_CHANNEL_REAUTHENTICATE_PERIOD - Static variable in class alluxio.conf.PropertyKey.Name
 
AUTHENTICATION_IS_NOT_ENABLED - alluxio.exception.ExceptionMessage
 
AuthenticationProvider - Interface in alluxio.security.authentication
Abstraction for an authentication provider at SASL server for AuthType.SIMPLE and AuthType.CUSTOM.
AuthenticationProvider.Factory - Class in alluxio.security.authentication
AuthenticationServer - Interface in alluxio.security.authentication
Interface for authentication server implementations.
AuthenticationUtils - Class in alluxio.security.authentication
This class provides util methods for AuthenticationUtilss.
authority() - Method in class alluxio.grpc.GrpcChannel
 
Authority - Interface in alluxio.uri
This interface represents the authority part of a URI.
AuthType - Enum in alluxio.security.authentication
Different authentication types for Alluxio.
AutopsyThread - Class in alluxio.thread
This thread is able to capture uncaught exceptions from run() so other classes can check the status of the thread and know why it crashed.
AutopsyThread() - Constructor for class alluxio.thread.AutopsyThread
Constructor.
available() - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Returns a read-only view of the available base factories.
await() - Method in class alluxio.concurrent.CountingLatch
Blocked during awaiting the counter to become zero.
await(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Waits for the given thread to be ready to be scheduled.
await(String, long, TimeUnit) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Waits until the given thread can be executed, throwing an unchecked exception of the given timeout expires.
awaitQuiescence(long, TimeUnit) - Method in class alluxio.concurrent.jsr.ForkJoinPool
If called by a ForkJoinTask operating in this pool, equivalent in effect to ForkJoinTask.helpQuiesce().
awaitTermination() - Method in class alluxio.grpc.GrpcServer
Waits until the server is terminated.
awaitTermination(long, TimeUnit) - Method in class alluxio.concurrent.jsr.ForkJoinPool
Blocks until all tasks have completed execution after a shutdown request, or the timeout occurs, or the current thread is interrupted, whichever happens first.
awaitTermination(long, TimeUnit) - Method in class alluxio.metrics.InstrumentedExecutorService
 
awaitTermination(long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
AWS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
AWS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 

B

BackoffStrategy - Enum in alluxio.worker.block.management
Used to specify from where to back-off.
BackupAbortedException - Exception in alluxio.exception
Thrown when backup is aborted.
BackupAbortedException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.BackupAbortedException
Constructs a new exception with the specified exception message and multiple parameters.
BackupAbortedException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.BackupAbortedException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
BackupAbortedException(String) - Constructor for exception alluxio.exception.BackupAbortedException
Constructs a new exception with the specified detail message.
BackupAbortedException(String, Throwable) - Constructor for exception alluxio.exception.BackupAbortedException
Constructs a new exception with the specified detail message and cause.
BackupDelegationException - Exception in alluxio.exception
Thrown when backup delegation fails.
BackupDelegationException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.BackupDelegationException
Constructs a new exception with the specified exception message and multiple parameters.
BackupDelegationException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.BackupDelegationException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
BackupDelegationException(String) - Constructor for exception alluxio.exception.BackupDelegationException
Constructs a new exception with the specified detail message.
BackupDelegationException(String, Throwable) - Constructor for exception alluxio.exception.BackupDelegationException
Constructs a new exception with the specified detail message and cause.
BackupException - Exception in alluxio.exception
Thrown when backup is fails.
BackupException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.BackupException
Constructs a new exception with the specified exception message and multiple parameters.
BackupException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.BackupException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
BackupException(String) - Constructor for exception alluxio.exception.BackupException
Constructs a new exception with the specified detail message.
BackupException(String, Throwable) - Constructor for exception alluxio.exception.BackupException
Constructs a new exception with the specified detail message and cause.
BackupStatus - Class in alluxio.wire
Defines the status of a backup.
BackupStatus(BackupState) - Constructor for class alluxio.wire.BackupStatus
Creates a new backup status with new Id.
BackupStatus(BackupStatus) - Constructor for class alluxio.wire.BackupStatus
Cloning constructor.
BackupStatus(UUID, BackupState) - Constructor for class alluxio.wire.BackupStatus
Creates a new backup status with existing Id.
BaseUnderFileSystem - Class in alluxio.underfs
A base abstract UnderFileSystem.
BaseUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.BaseUnderFileSystem
Constructs an BaseUnderFileSystem.
BaseUserState - Class in alluxio.security.user
Base implementation of UserState.
BaseUserState(Subject, AlluxioConfiguration) - Constructor for class alluxio.security.user.BaseUserState
 
beforeConnect() - Method in class alluxio.AbstractClient
This method is called before the connection is connected.
beforeConnect() - Method in class alluxio.AbstractMasterClient
 
beforeDisconnect() - Method in class alluxio.AbstractClient
This method is called before the connection is disconnected.
belongsTo(BlockStoreLocation) - Method in class alluxio.worker.block.BlockStoreLocation
Returns whether this location belongs to the specific location.
BFS - alluxio.master.file.MetadataSyncTraversalOrder
 
BitSet - Interface in alluxio.collections
An interface of BitSet supports get/set/clear.
block() - Method in interface alluxio.concurrent.jsr.ForkJoinPool.ManagedBlocker
Possibly blocks the current thread, for example waiting for a lock or condition.
BLOCK_ID_FOR_DIFFERENT_SESSION - alluxio.exception.ExceptionMessage
 
BLOCK_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
BLOCK_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
BLOCK_MASTER_NAME - Static variable in class alluxio.Constants
 
BLOCK_MASTER_WORKER_SERVICE_NAME - Static variable in class alluxio.Constants
 
BLOCK_MASTER_WORKER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
BLOCK_META_NOT_FOUND - alluxio.exception.ExceptionMessage
 
BLOCK_NOT_FOUND_FOR_SESSION - alluxio.exception.ExceptionMessage
 
BLOCK_WORKER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
BLOCK_WORKER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
BLOCK_WORKER_NAME - Static variable in class alluxio.Constants
 
BLOCK_WRITE_LOCATION_POLICY_UNSPECIFIED - alluxio.exception.PreconditionMessage
 
BlockAlreadyExistsException - Exception in alluxio.exception
The exception thrown when a block already exists in Alluxio.
BlockAlreadyExistsException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.BlockAlreadyExistsException
Constructs a new exception with the specified exception message and multiple parameters.
BlockAlreadyExistsException(String) - Constructor for exception alluxio.exception.BlockAlreadyExistsException
Constructs a new exception with the specified exception message.
BlockClient - Class in alluxio.worker.block.io
Provides basic tracking and representation for block reader/writer clients.
BlockClient(BlockClient.Type) - Constructor for class alluxio.worker.block.io.BlockClient
Creates an abstract block reader/writer.
BlockClient.Type - Enum in alluxio.worker.block.io
Block client type.
BlockClientListener - Interface in alluxio.worker.block.io
An interface to listen for creation and destruction of block clients.
BlockDoesNotExistException - Exception in alluxio.exception
The exception thrown when a block does not exist in Alluxio.
BlockDoesNotExistException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.BlockDoesNotExistException
Constructs a new exception with the specified exception message and multiple parameters.
BlockDoesNotExistException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.BlockDoesNotExistException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
BlockDoesNotExistException(String) - Constructor for exception alluxio.exception.BlockDoesNotExistException
Constructs a new exception with the specified detail message.
BlockDoesNotExistException(String, Throwable) - Constructor for exception alluxio.exception.BlockDoesNotExistException
Constructs a new exception with the specified detail message and cause.
BlockDoesNotExistRuntimeException - Exception in alluxio.exception.runtime
The exception thrown when a block does not exist in Alluxio.
BlockDoesNotExistRuntimeException(long) - Constructor for exception alluxio.exception.runtime.BlockDoesNotExistRuntimeException
Constructs a new exception with the specified detail message and cause.
BlockHeartbeatReport - Class in alluxio.worker.block
Container for the delta information in each worker-to-master heartbeat.
BlockHeartbeatReport(Map<BlockStoreLocation, List<Long>>, List<Long>, Map<String, List<String>>) - Constructor for class alluxio.worker.block.BlockHeartbeatReport
Creates a new instance of BlockHeartbeatReport.
BlockId - Class in alluxio.master.block
This class provides a set of methods related to block IDs.
BlockInfo - Class in alluxio.wire
The block information.
BlockInfo() - Constructor for class alluxio.wire.BlockInfo
Creates a new instance of BlockInfo.
BlockInfoException - Exception in alluxio.exception
The exception thrown when something with the block goes wrong, i.e.
BlockInfoException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.BlockInfoException
Constructs a new exception with the specified exception message and multiple parameters.
BlockInfoException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.BlockInfoException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
BlockInfoException(String) - Constructor for exception alluxio.exception.BlockInfoException
Constructs a new exception with the specified detail message.
BlockInfoException(String, Throwable) - Constructor for exception alluxio.exception.BlockInfoException
Constructs a new exception with the specified detail message and cause.
BlockLocation - Class in alluxio.wire
The location of a block.
BlockLocation() - Constructor for class alluxio.wire.BlockLocation
Creates a new instance of BlockLocation.
BlockLocationInfo - Class in alluxio.wire
The file block with location information.
BlockLocationInfo(FileBlockInfo, List<WorkerNetAddress>) - Constructor for class alluxio.wire.BlockLocationInfo
 
BlockLock - Class in alluxio.worker.block
A resource lock for block.
BlockLock(long, Consumer<Long>) - Constructor for class alluxio.worker.block.BlockLock
 
BlockMasterInfo - Class in alluxio.wire
The Alluxio block master information.
BlockMasterInfo() - Constructor for class alluxio.wire.BlockMasterInfo
Creates a new instance of BlockMasterInfo.
BlockMasterInfo.BlockMasterInfoField - Enum in alluxio.wire
Enum representing the fields of the block master info.
BlockMeta - Interface in alluxio.worker.block.meta
Metadata of a block in Alluxio managed storage served by workers.
BlockReadableChannel - Class in alluxio.worker.block.io
Readable channel implementation for BlockReaders.
BlockReadableChannel(BlockReader) - Constructor for class alluxio.worker.block.io.BlockReadableChannel
Creates a new channel from a block reader.
BlockReader - Class in alluxio.worker.block.io
An abstract reader class to access the data of a block stored in managed storage.
BlockReader() - Constructor for class alluxio.worker.block.io.BlockReader
Default constructor for the abstract reader implementations.
BlockReaderFactory - Interface in alluxio.worker.block
Factory for block reader.
BlockReadRequest - Class in alluxio.wire
The internal representation of a block read request.
BlockStore - Interface in alluxio.worker.block
An abstraction of block store on worker.
BlockStoreEventListener - Interface in alluxio.worker.block
A listener interface for receiving metadata mutation events of BlockStore.
BlockStoreLocation - Class in alluxio.worker.block
Where to store a block within a block store.
BlockStoreLocation(String, int) - Constructor for class alluxio.worker.block.BlockStoreLocation
Creates a new instance of BlockStoreLocation.
BlockStoreLocation(String, int, String) - Constructor for class alluxio.worker.block.BlockStoreLocation
Creates a new instance of BlockStoreLocation.
BlockStoreMeta - Interface in alluxio.worker.block
Interface for the block store meta in Alluxio.
BlockStoreType - Enum in alluxio.worker.block
The different implementation of LocalBlockStore that can be instantiated.
BlockWorker - Interface in alluxio.worker.block
A block worker in the Alluxio system.
BlockWriter - Class in alluxio.worker.block.io
An abstract writer class to write or update a block stored in managed storage.
BlockWriter() - Constructor for class alluxio.worker.block.io.BlockWriter
Default constructor for the abstract writer implementations.
BlockWriterFactory - Interface in alluxio.worker.block
Factory for block reader.
BOOLEAN - alluxio.conf.PropertyKey.PropertyType
The Property's value is of boolean type, stored as a Boolean.
booleanBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
bossEventLoopGroup(EventLoopGroup) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the boss EventLoopGroup.
BucketCounter - Class in alluxio.util
Bucket Counter Utility.
BucketCounter(List<Long>) - Constructor for class alluxio.util.BucketCounter
Bucket Counter constructor.
BufferRepository<TMesg,​TBuf> - Interface in alluxio.grpc
A repository of buffers.
BufferUtils - Class in alluxio.util.io
Utilities related to buffers, not only ByteBuffer.
build() - Method in class alluxio.conf.PropertyKey.Builder
Creates and registers the property key.
build() - Method in class alluxio.grpc.GrpcChannelBuilder
Creates an authenticated channel of type GrpcChannel.
build() - Method in class alluxio.grpc.GrpcServerBuilder
Build the server.
build() - Method in class alluxio.job.JobDescription.Builder
build job description.
build() - Method in class alluxio.master.MasterClientContextBuilder
 
build() - Method in class alluxio.metrics.MetricKey.Builder
Creates and registers the Metric key.
build() - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
build() - Method in class alluxio.security.authorization.AclEntry.Builder
 
build() - Method in class alluxio.util.UnixMountInfo.Builder
 
build() - Method in class alluxio.util.UnixMountInfo.Options.Builder
 
build() - Method in class alluxio.wire.Configuration.Builder
 
build(String, boolean) - Static method in class alluxio.util.ThreadFactoryUtils
Creates a ThreadFactory that spawns off threads.
builder() - Static method in class alluxio.retry.ExponentialTimeBoundedRetry
 
Builder() - Constructor for class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
Builder() - Constructor for class alluxio.security.authorization.AclEntry.Builder
Creates a new builder where type is null, subject is an empty string, and no action is permitted.
Builder() - Constructor for class alluxio.util.UnixMountInfo.Builder
Constructs a new Unix mount info builder.
Builder() - Constructor for class alluxio.util.UnixMountInfo.Options.Builder
Constructs a new unix mount info options builder.
Builder() - Constructor for class alluxio.wire.Configuration.Builder
 
Builder(PropertyKey.PropertyType, PropertyKey.Template, Object...) - Constructor for class alluxio.conf.PropertyKey.Builder
 
Builder(PropertyKey.PropertyType, Optional<String>, PropertyKey.Template, Object...) - Constructor for class alluxio.conf.PropertyKey.Builder
 
Builder(PropertyKey.Template, Object...) - Constructor for class alluxio.conf.PropertyKey.Builder
 
Builder(String) - Constructor for class alluxio.metrics.MetricKey.Builder
 
buildFjp(String, boolean) - Static method in class alluxio.util.ThreadFactoryUtils
Creates a ForkJoinPool.ForkJoinWorkerThreadFactory that spawns off threads for ForkJoinPool.
buildUnregistered() - Method in class alluxio.conf.PropertyKey.Builder
Creates the property key without registering it with default property list.
BuiltinBitSet - Class in alluxio.collections
This class is a wrapper of java's builtin BitSet.
BuiltinBitSet(int) - Constructor for class alluxio.collections.BuiltinBitSet
Creates a new bit set.
BusyException - Exception in alluxio.exception
Thrown when the system is busy.
BusyException() - Constructor for exception alluxio.exception.BusyException
Constructs a new busy exception.
BYTE - alluxio.client.file.CacheContext.StatsUnit
 
byteArray() - Method in class alluxio.file.ByteArrayTargetBuffer
 
byteArray() - Method in class alluxio.file.ByteBufferTargetBuffer
 
byteArray() - Method in class alluxio.file.NettyBufTargetBuffer
 
byteArray() - Method in interface alluxio.file.ReadTargetBuffer
 
ByteArrayTargetBuffer - Class in alluxio.file
Target buffer backed by bytes array for zero-copy read from page store.
ByteArrayTargetBuffer(byte[], int) - Constructor for class alluxio.file.ByteArrayTargetBuffer
Constructor.
byteArrayToHexString(byte[]) - Static method in class alluxio.util.FormatUtils
Parses a byte array into a space separated hex string where each byte is represented in the format 0x%02x.
byteArrayToHexString(byte[], String, String) - Static method in class alluxio.util.FormatUtils
Parses a byte array into a hex string where each byte is represented in the format %02x.
byteBuffer() - Method in class alluxio.file.ByteArrayTargetBuffer
 
byteBuffer() - Method in class alluxio.file.ByteBufferTargetBuffer
 
byteBuffer() - Method in class alluxio.file.NettyBufTargetBuffer
 
byteBuffer() - Method in interface alluxio.file.ReadTargetBuffer
 
ByteBufferTargetBuffer - Class in alluxio.file
Target buffer backed by nio ByteBuffer for zero-copy read from page store.
ByteBufferTargetBuffer(ByteBuffer) - Constructor for class alluxio.file.ByteBufferTargetBuffer
Constructor.
byteBufferToString(ByteBuffer) - Static method in class alluxio.util.FormatUtils
Parses a ByteBuffer into a String.
byteChannel() - Method in class alluxio.file.ByteArrayTargetBuffer
 
byteChannel() - Method in class alluxio.file.ByteBufferTargetBuffer
 
byteChannel() - Method in class alluxio.file.NettyBufTargetBuffer
 
byteChannel() - Method in interface alluxio.file.ReadTargetBuffer
 
ByteIOUtils - Class in alluxio.util.io
A collection of utility functions to read/write primitive values from/to a byte array.
BYTES_IN_INTEGER - Static variable in class alluxio.Constants
 
byteToInt(byte) - Static method in class alluxio.util.io.BufferUtils
Converts a byte to an integer.

C

cache(CacheRequest) - Method in interface alluxio.worker.block.BlockWorker
Submits the cache request to cache manager to execute.
CACHE - alluxio.client.ReadType
Read the file and cache it in the highest tier of a local worker.
CACHE_PROMOTE - alluxio.client.ReadType
Read the file and cache it in a local worker.
CACHE_THROUGH - alluxio.client.WriteType
Write the file synchronously to the under fs, and also try to write to the highest tier in a worker's Alluxio storage.
CACHE_UFS_SESSION_ID - Static variable in class alluxio.Sessions
 
CACHE_WORKER_SESSION_ID - Static variable in class alluxio.Sessions
 
CacheContext - Class in alluxio.client.file
Cache related context.
CacheContext() - Constructor for class alluxio.client.file.CacheContext
Expected to be inherited in PrestoDB or other local cache caller.
CacheContext.StatsUnit - Enum in alluxio.client.file
Stats Unit.
CachedGroupMapping - Class in alluxio.security.group
Class to map user to groups.
CachedGroupMapping(GroupMappingService, long) - Constructor for class alluxio.security.group.CachedGroupMapping
Constructor with specified GroupMappingService.
cachedThreadPool(String) - Static method in class alluxio.util.executor.ExecutorServiceFactories
Returns a ExecutorServiceFactory which creates threadpool executors with the given base name.
CacheQuota - Class in alluxio.client.quota
Data structure that stores and returns cache size in number of bytes associated with a cache scope.
CacheQuota() - Constructor for class alluxio.client.quota.CacheQuota
Empty cache quota.
CacheQuota(Map<CacheScope.Level, Long>) - Constructor for class alluxio.client.quota.CacheQuota
 
CacheScope - Class in alluxio.client.quota
This class defines "Scope" of a cache quota.
CacheScope.Level - Enum in alluxio.client.quota
Level of a scope.
calculateObjectSize(Object) - Method in class alluxio.util.ObjectSizeCalculator
Given an object, returns the total allocated size, in bytes, of the object and all other objects reachable from it.
call() - Method in interface alluxio.AbstractClient.RpcCallable
The task where RPC happens.
call() - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer.OperationThread
 
call(NettyRPCContext, ProtoMessage) - Static method in class alluxio.network.netty.NettyRPC
Sends a request and waits for a response.
cancel(boolean) - Method in class alluxio.concurrent.jsr.CompletableFuture
If not already completed, completes this CompletableFuture with a CancellationException.
cancel(boolean) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Attempts to cancel execution of this task.
CanceledException - Exception in alluxio.exception.status
Exception indicating that an operation was cancelled (typically by the caller).
CanceledException(String) - Constructor for exception alluxio.exception.status.CanceledException
 
CanceledException(String, Throwable) - Constructor for exception alluxio.exception.status.CanceledException
 
CanceledException(Throwable) - Constructor for exception alluxio.exception.status.CanceledException
 
CancelledException - Exception in alluxio.exception.status
Exception indicating that an operation was cancelled (typically by the caller).
CancelledException(String) - Constructor for exception alluxio.exception.status.CancelledException
 
CancelledException(String, Throwable) - Constructor for exception alluxio.exception.status.CancelledException
 
CancelledException(Throwable) - Constructor for exception alluxio.exception.status.CancelledException
 
CancelledRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that the service is cancelled or interrupted (typically by the caller).
CancelledRuntimeException(String) - Constructor for exception alluxio.exception.runtime.CancelledRuntimeException
Constructor.
CancelledRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.CancelledRuntimeException
Constructor.
CANNOT_FREE_NON_EMPTY_DIR - alluxio.exception.ExceptionMessage
 
CANNOT_FREE_NON_PERSISTED_FILE - alluxio.exception.ExceptionMessage
 
CANNOT_FREE_PINNED_FILE - alluxio.exception.ExceptionMessage
 
CANNOT_REQUEST_SPACE - alluxio.exception.ExceptionMessage
 
canUseReservedSpace() - Method in class alluxio.worker.block.AllocateOptions
 
Capacity - Class in alluxio.wire
Class that represents the available, free, and total capacity.
Capacity() - Constructor for class alluxio.wire.Capacity
Creates a new instance of Capacity.
CAPACITY_BYTES - alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 
CAPACITY_BYTES_ON_TIERS - alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 
castToIOException(Throwable) - Static method in class alluxio.util.CommonUtils
Casts a Throwable to an IOException.
changeLocalFileGroup(String, String) - Static method in class alluxio.util.io.FileUtils
Changes the local file's group.
changeLocalFilePermission(String, String) - Static method in class alluxio.util.io.FileUtils
Changes local file's permission.
changeLocalFileToFullPermission(String) - Static method in class alluxio.util.io.FileUtils
Changes local file's permission to be "rwxrwxrwx".
changeLocalFileUser(String, String) - Static method in class alluxio.util.io.FileUtils
Changes the local file's user.
CHANNEL_TYPE - Static variable in class alluxio.util.network.NettyUtils
 
ChannelAdapters - Class in alluxio.util.io
Channel adapters.
ChannelIdInjector - Class in alluxio.security.authentication
Client side interceptor that is used to augment outgoing metadata with the unique id for the channel that the RPC is being called on.
ChannelIdInjector(UUID) - Constructor for class alluxio.security.authentication.ChannelIdInjector
Creates the injector that augments the outgoing metadata with given Id.
channelRead(ChannelHandlerContext, Object) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
 
channelType(Class<? extends ServerChannel>) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the netty channel type.
ChannelType - Enum in alluxio.network
What type of netty channel to use.
channelUnregistered(ChannelHandlerContext) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
 
CHECK_FILE_EXISTS - Static variable in class alluxio.conf.PropertyKey
 
checkMinimalPollingPeriod(TimeUnit, int) - Static method in class alluxio.metrics.MetricsSystem
Checks if the poll period is smaller that the minimal poll period which is 1 second.
checkNumOfArgsEquals(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
Checks the number of non-option arguments equals n for command.
checkNumOfArgsNoLessThan(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
Checks the number of non-option arguments is no less than n for command.
checkNumOfArgsNoMoreThan(Command, CommandLine, int) - Static method in class alluxio.cli.CommandUtils
Checks the number of non-option arguments is no more than n for command.
checkPermission(String, List<String>, AclAction) - Method in class alluxio.security.authorization.AccessControlList
Checks whether the user has the permission to perform the action.
checkRatio(AlluxioConfiguration, PropertyKey) - Static method in class alluxio.util.ConfigurationUtils
Checks that the given property key is a ratio from 0.0 and 1.0, throwing an exception if it is not.
checkSupported(AuthType) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
Used to check if given authentication is supported by the server.
checkVersion(long) - Method in class alluxio.AbstractClient
Checks that the service version is compatible with the client.
CLASS - alluxio.conf.PropertyKey.PropertyType
The Property's value is of class type, stored as a Class.
CLASS_NAME_FIELD - Static variable in interface alluxio.util.JsonSerializable
This must match the java field for the class name.
classBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
cleanDirectBuffer(ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Forces to unmap a direct buffer if this buffer is no longer used.
cleanPath(String) - Static method in class alluxio.util.io.PathUtils
Checks and normalizes the given path.
cleanup() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
cleanup() - Method in class alluxio.underfs.ObjectUnderFileSystem
 
cleanup() - Method in interface alluxio.underfs.UnderFileSystem
Cleans up the under file system.
cleanup() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
cleanupSession(long) - Method in interface alluxio.worker.SessionCleanable
Cleans up the session.
cleanupSessionTempBlocks(long, List<Long>) - Method in interface alluxio.worker.block.meta.StorageDir
Cleans up the temp block metadata for each block id passed in.
clear() - Method in class alluxio.collections.ConcurrentHashSet
 
clear() - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
clear() - Method in class alluxio.collections.DelegatingSet
 
clear() - Method in interface alluxio.collections.FieldIndex
Removes all the entries in this index.
clear() - Method in class alluxio.collections.IndexedSet
Removes all the entries in this set.
clear() - Method in class alluxio.collections.NonUniqueFieldIndex
 
clear() - Method in class alluxio.collections.UniqueFieldIndex
 
clear() - Method in class alluxio.collections.UnmodifiableArrayList
 
clear() - Method in class alluxio.conf.AlluxioProperties
Clears all existing user-specified properties.
clear() - Method in class alluxio.conf.path.TrieNode
Recursively removes all children.
clear(int) - Method in interface alluxio.collections.BitSet
Sets the bit specified by the index to false.
clear(int) - Method in class alluxio.collections.BuiltinBitSet
 
clearAllMetrics() - Static method in class alluxio.metrics.MetricsSystem
Resets the metric registry and removes all the metrics.
clearEntries() - Method in class alluxio.security.authorization.AccessControlList
Clears out all entries (does not modify the owner name and owning group).
clearMetrics() - Method in interface alluxio.worker.block.BlockWorker
Clears the worker metrics.
clearTimer(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Removes a timer name from the scheduler if it exists.
Client - Interface in alluxio
Interface for a client in the Alluxio system.
CLIENT - alluxio.metrics.MetricsSystem.InstanceType
 
CLIENT - alluxio.util.CommonUtils.ProcessType
 
CLIENT_BLOCK_MASTER_CLIENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BLOCK_READ_CHUNK_REMOTE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BLOCK_WORKER_CLIENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BUSY_EXCEPTION_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_READ_LOCAL - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_READ_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_WRITTEN_LOCAL - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_WRITTEN_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_DISCARDED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_EVICTED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_READ_CACHE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_READ_EXTERNAL - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_READ_IN_STREAM_BUFFER - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_REQUESTED_EXTERNAL - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_BYTES_WRITTEN_CACHE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_CLEAN_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_CLEANUP_GET_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_CLEANUP_PUT_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_CREATE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_DELETE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_DELETE_FROM_STORE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_DELETE_NON_EXISTING_PAGE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_DELETE_NOT_READY_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_GET_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_GET_NOT_READY_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_GET_STORE_READ_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_HIT_RATE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGE_READ_CACHE_TIME_NS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGE_READ_EXTERNAL_TIME_NS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGES - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGES_DISCARDED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PAGES_EVICTED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_ASYNC_REJECTION_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_BENIGN_RACING_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_EVICTION_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_INSUFFICIENT_SPACE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_NOT_READY_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_STORE_DELETE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_STORE_WRITE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_PUT_STORE_WRITE_NO_SPACE_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_BYTES - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_BYTES_HIT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_BYTES_READ - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_FALSE_POSITIVE_RATIO - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_PAGES - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_PAGES_HIT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SHADOW_CACHE_PAGES_READ - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SPACE_AVAILABLE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SPACE_USED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_SPACE_USED_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_STATE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_STORE_DELETE_TIMEOUT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_STORE_GET_TIMEOUT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_STORE_PUT_TIMEOUT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_CACHE_STORE_THREADS_REJECTED - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_DEFAULT_HIVE_CLIENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_FILE_SYSTEM_MASTER_CLIENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_META_DATA_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
CLIENT_UFS_FALLBACK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
clientClosed(BlockClient, BlockStoreLocation) - Method in interface alluxio.worker.block.io.BlockClientListener
Called when an open block client is closed.
ClientContext - Class in alluxio
A ClientContext contains information required and pertaining to making network connections and performing operations with remote Alluxio processes.
ClientContext(ClientContext) - Constructor for class alluxio.ClientContext
This constructor does not create a copy of the configuration.
ClientIpAddressInjector - Class in alluxio.security.authentication
Server side interceptor that is used to put remote client's IP Address to thread local storage.
ClientIpAddressInjector() - Constructor for class alluxio.security.authentication.ClientIpAddressInjector
 
clientOpened(BlockClient, BlockStoreLocation) - Method in interface alluxio.worker.block.io.BlockClientListener
Called when a new block client is opened.
ClientRWLock - Class in alluxio.concurrent
Read/write lock associated with clients rather than threads.
ClientRWLock(int) - Constructor for class alluxio.concurrent.ClientRWLock
Constructs a new ClientRWLock.
CLOCK_CUCKOO_FILTER - alluxio.client.file.cache.ShadowCacheType
A shadow cache with clock cuckoo filter implementation.
cloneByteBuffer(ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Clones a ByteBuffer.
cloneByteBufferList(List<ByteBuffer>) - Static method in class alluxio.util.io.BufferUtils
Clones a list of ByteBuffers.
close() - Method in class alluxio.AbstractClient
Closes the connection with the remote permanently.
close() - Method in class alluxio.cli.AbstractShell
 
close() - Method in interface alluxio.cli.Command
Used to close resources created by commands.
close() - Method in class alluxio.CloseableSupplier
 
close() - Method in class alluxio.collections.LockPool
 
close() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
close() - Method in interface alluxio.grpc.BufferRepository
Closes the repository and all its buffers.
close() - Method in class alluxio.grpc.DataMessageMarshaller
 
close() - Method in class alluxio.grpc.GrpcChannel
Releases the connection to the pool.
close() - Method in interface alluxio.heartbeat.HeartbeatExecutor
Cleans up any resources used by the heartbeat executor.
close() - Method in class alluxio.master.ZkMasterInquireClient
 
close() - Method in class alluxio.metrics.MetricsSystem.MultiTimerContext
Updates the timer with the difference between current and start time.
close() - Method in interface alluxio.PositionReader
Closes the positon reader and do cleanup job if any.
close() - Method in class alluxio.resource.CloseableResource
 
close() - Method in class alluxio.resource.DynamicResourcePool
Closes the pool and clears all the resources.
close() - Method in class alluxio.resource.LockResource
Releases the lock.
close() - Method in class alluxio.resource.RefCountLockResource
Releases the lock and decrement the ref count if a ref counter was provided at construction time.
close() - Method in class alluxio.resource.ResourcePool
Closes the resource pool.
close() - Method in class alluxio.security.authentication.AbstractSaslClientHandler
This is synchronized in order to protect AbstractSaslClientHandler.mSaslClient.
close() - Method in class alluxio.security.authentication.AbstractSaslServerHandler
 
close() - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
Stops authenticated session with the server by releasing the long poll.
close() - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
Completes authenticated channel.
close() - Method in interface alluxio.security.authentication.AuthenticationServer
Closes the server, releases all authentication sessions.
close() - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
close() - Method in interface alluxio.security.authentication.SaslClientHandler
Close the handler and dispose internal resources.
close() - Method in interface alluxio.security.authentication.SaslServerHandler
Close the handler and dispose internal resources.
close() - Method in interface alluxio.Server
Closes the server.
close() - Method in class alluxio.underfs.AtomicFileOutputStream
 
close() - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
close() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
close() - Method in class alluxio.underfs.ObjectUnderFileSystem
 
close() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
close() - Method in interface alluxio.util.interfaces.Scoped
 
close() - Method in class alluxio.worker.block.io.BlockClient
 
close() - Method in class alluxio.worker.block.io.BlockReadableChannel
 
close() - Method in class alluxio.worker.block.io.DelegatingBlockReader
 
close() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
close() - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
CLOSE - alluxio.metrics.MetricInfo.UfsOps
 
CLOSE_ALLUXIO_OUTSTREAM_LATENCY - Static variable in class alluxio.metrics.MetricKey
 
CLOSE_UFS_OUTSTREAM_LATENCY - Static variable in class alluxio.metrics.MetricKey
 
CloseableIterator<T> - Class in alluxio.resource
A CloseableIterator<T> is an iterator which requires cleanup when it is no longer in use.
CloseableResource<T> - Class in alluxio.resource
A CloseableResource<T> is a wrapper around a resource of type T which must do some sort of cleanup when it is no longer in use.
CloseableResource(T) - Constructor for class alluxio.resource.CloseableResource
Creates a CloseableResource wrapper around the given resource.
CloseableSupplier<T extends java.io.Closeable> - Class in alluxio
Closeable supplier which supports lazy initialization and cleanup if initialized.
CloseableSupplier(Supplier<T>) - Constructor for class alluxio.CloseableSupplier
 
closeAndRethrow(Closer, Throwable) - Static method in class alluxio.util.CommonUtils
Closes the Closer and re-throws the Throwable.
closeAndRethrowRuntimeException(Closer, Throwable) - Static method in class alluxio.util.CommonUtils
closeChannel(Channel) - Static method in class alluxio.util.CommonUtils
Closes the netty channel from outside the netty I/O thread.
closeResource() - Method in class alluxio.resource.CloseableResource
Performs any cleanup operations necessary when the resource is no longer in use.
closeResource() - Method in class alluxio.resource.PooledResource
 
closeResource() - Method in class alluxio.worker.block.BlockLock
 
closeResource(Channel) - Method in class alluxio.network.netty.NettyChannelPool
 
closeResource(T) - Method in class alluxio.resource.DynamicResourcePool
Closes the resource.
closeUfsBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Closes a UFS block for a client session.
CLUSTER - alluxio.metrics.MetricsSystem.InstanceType
 
CLUSTER - Static variable in class alluxio.metrics.MetricsSystem
 
CLUSTER_ACTIVE_RPC_READ_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_ACTIVE_RPC_WRITE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_DIRECT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_DIRECT_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_DOMAIN - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_LOCAL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_REMOTE - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_REMOTE_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_UFS - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_UFS_ALL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_READ_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_DOMAIN - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_LOCAL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_LOCAL_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_REMOTE - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_REMOTE_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_UFS_ALL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_BYTES_WRITTEN_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_CACHE_HIT_RATE - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_DEFAULT - alluxio.conf.Source.Type
The default property value as loaded from the masters of the cluster.
CLUSTER_DEFAULT - Static variable in class alluxio.conf.Source
 
CLUSTER_LEADER_ID - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_LEADER_INDEX - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_LOST_WORKERS - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_ROOT_UFS_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_ROOT_UFS_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_ROOT_UFS_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
 
CLUSTER_WORKERS - Static variable in class alluxio.metrics.MetricKey
 
clusterDefaultsLoaded() - Method in interface alluxio.conf.AlluxioConfiguration
 
clusterDefaultsLoaded() - Method in class alluxio.conf.InstancedConfiguration
 
clusterDefaultsLoaded() - Method in class alluxio.conf.path.SpecificPathConfiguration
 
clusterDefaultsLoaded() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
combine(Scope, Scope) - Static method in class alluxio.grpc.GrpcUtils
 
combineData(DataMessage<ReadResponse, DataBuffer>) - Method in class alluxio.grpc.ReadResponseMarshaller
 
combineData(DataMessage<WriteRequest, DataBuffer>) - Method in class alluxio.grpc.WriteRequestMarshaller
 
combineData(DataMessage<T, DataBuffer>) - Method in class alluxio.grpc.DataMessageMarshaller
Combines the data buffer into the message.
Command - Interface in alluxio.cli
An interface for all the commands that can be run from a shell.
CommandReturn - Class in alluxio.shell
Object representation of a command execution.
CommandReturn(int, String) - Constructor for class alluxio.shell.CommandReturn
Creates object from the contents.
CommandReturn(int, String[], String) - Constructor for class alluxio.shell.CommandReturn
Creates object from the contents.
CommandType - Enum in alluxio.wire
Types for file system commands.
CommandUtils - Class in alluxio.cli
Class for convenience methods used by instances of Command.
commit() - Method in class alluxio.security.login.AlluxioLoginModule
Commits the authentication (second phase).
commit() - Method in class alluxio.security.login.AppLoginModule
Commits the authentication (second phase).
commitBlock(long, long, boolean) - Method in interface alluxio.worker.block.BlockStore
Commits a block to Alluxio managed space.
commitBlock(long, long, boolean) - Method in interface alluxio.worker.block.BlockWorker
Commits a block to Alluxio managed space.
commitBlockInUfs(long, long) - Method in interface alluxio.worker.block.BlockWorker
Commits a block in UFS.
COMMON_SSH_OPTS - Static variable in class alluxio.util.ShellUtils
Common shell OPTS to prevent stalling.
commonPool() - Static method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the common pool instance.
CommonUtils - Class in alluxio.util
Common utilities shared by all components in Alluxio.
CommonUtils.ProcessType - Enum in alluxio.util
Alluxio process types.
compare(WorkerInfo, WorkerInfo) - Method in class alluxio.wire.WorkerInfo.LastContactSecComparator
 
compare(String, String) - Static method in class alluxio.util.URIUtils
 
compareAndSetForkJoinTaskTag(short, short) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Atomically conditionally sets the tag value for this task.
compareAndSetPendingCount(int, int) - Method in class alluxio.concurrent.jsr.CountedCompleter
Sets (atomically) the pending count to the given count only if it currently holds the given expected value.
compareTo(AlluxioURI) - Method in class alluxio.AlluxioURI
 
compareTo(PropertyKey) - Method in class alluxio.conf.PropertyKey
 
compareTo(Source) - Method in class alluxio.conf.Source
 
compareTo(MetricKey) - Method in class alluxio.metrics.MetricKey
 
compareTo(Authority) - Method in interface alluxio.uri.Authority
 
compareTo(Authority) - Method in class alluxio.uri.EmbeddedLogicalAuthority
 
compareTo(Authority) - Method in class alluxio.uri.MultiMasterAuthority
 
compareTo(Authority) - Method in class alluxio.uri.ZookeeperLogicalAuthority
 
compareTo(URI) - Method in class alluxio.uri.StandardURI
 
compareTo(NodeInfo) - Method in class alluxio.util.webui.NodeInfo
Compare NodeInfo by lexicographical order of their associated host.
CompletableFuture<T> - Class in alluxio.concurrent.jsr
A Future that may be explicitly completed (setting its value and status), and may be used as a CompletionStage, supporting dependent functions and actions that trigger upon its completion.
CompletableFuture() - Constructor for class alluxio.concurrent.jsr.CompletableFuture
Creates a new incomplete CompletableFuture.
CompletableFuture.AsynchronousCompletionTask - Interface in alluxio.concurrent.jsr
A marker interface identifying asynchronous tasks produced by async methods.
complete(T) - Method in class alluxio.concurrent.jsr.CompletableFuture
If not already completed, sets the value returned by CompletableFuture.get() and related methods to the given value.
complete(T) - Method in class alluxio.concurrent.jsr.CountedCompleter
Regardless of pending count, invokes CountedCompleter.onCompletion(CountedCompleter), marks this task as complete and further triggers CountedCompleter.tryComplete() on this task's completer, if one exists.
complete(V) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Completes this task, and if not already aborted or cancelled, returning the given value as the result of subsequent invocations of join and related operations.
completeAsync(Supplier<? extends T>) - Method in class alluxio.concurrent.jsr.CompletableFuture
Completes this CompletableFuture with the result of the given Supplier function invoked from an asynchronous task using the default executor.
completeAsync(Supplier<? extends T>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
Completes this CompletableFuture with the result of the given Supplier function invoked from an asynchronous task using the given executor.
completedFuture(U) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is already completed with the given value.
completedStage(U) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletionStage that is already completed with the given value and supports only those methods in interface CompletionStage.
completeExceptionally(Throwable) - Method in class alluxio.concurrent.jsr.CompletableFuture
If not already completed, causes invocations of CompletableFuture.get() and related methods to throw the given exception.
completeExceptionally(Throwable) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Completes this task abnormally, and if not already aborted or cancelled, causes it to throw the given exception upon join and related operations.
completeMultiPartUploadInternal() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
completeOnTimeout(T, long, TimeUnit) - Method in class alluxio.concurrent.jsr.CompletableFuture
Completes this CompletableFuture with the given value if not otherwise completed before the given timeout.
CompletionStage<T> - Interface in alluxio.concurrent.jsr
A stage of a possibly asynchronous computation, that performs an action or computes a value when another CompletionStage completes.
compute() - Method in class alluxio.concurrent.jsr.CountedCompleter
The main computation performed by this task.
computeNextWaitTime() - Method in class alluxio.retry.ExponentialTimeBoundedRetry
 
computeNextWaitTime() - Method in class alluxio.retry.TimeBoundedRetry
 
concat(CloseableIterator<T>, CloseableIterator<T>) - Static method in class alluxio.resource.CloseableIterator
Combines two iterators into a single iterator.
concat(List<CloseableIterator<T>>) - Static method in class alluxio.resource.CloseableIterator
Concatenates iterators.
concatPath(Object, Object) - Static method in class alluxio.util.io.PathUtils
Joins two path elements, separated by AlluxioURI.SEPARATOR.
concatPath(Object, Object...) - Static method in class alluxio.util.io.PathUtils
Joins each element in paths in order, separated by AlluxioURI.SEPARATOR.
concatUfsPath(String, String) - Static method in class alluxio.util.io.PathUtils
Join two path elements for ufs, separated by AlluxioURI.SEPARATOR.
ConcurrentHashSet<T> - Class in alluxio.collections
A concurrent hash set.
ConcurrentHashSet() - Constructor for class alluxio.collections.ConcurrentHashSet
Creates a new ConcurrentHashSet.
ConcurrentHashSet(int, float, int) - Constructor for class alluxio.collections.ConcurrentHashSet
Creates a new ConcurrentHashSet.
ConcurrentIdentityHashMap<K,​V> - Class in alluxio.collections
An implementation ConcurrentHashMap that utilizes identity semantics with its keys Having identity semantics means that it is possible to have two objects with which are equal based on the object's equals() implementation, but not be overridden in the hash map if you try to put both.
ConcurrentIdentityHashMap() - Constructor for class alluxio.collections.ConcurrentIdentityHashMap
Creates a new, empty map with the default initial table size (16).
ConcurrentIdentityHashMap(int) - Constructor for class alluxio.collections.ConcurrentIdentityHashMap
Creates a new, empty map with an initial table size accommodating the specified number of elements without having to dynamically resize.
ConcurrentIdentityHashMap(int, float) - Constructor for class alluxio.collections.ConcurrentIdentityHashMap
Creates a new, empty map with an initial table size based on the given number of elements (initialCapacity) and initial load factor (loadFactor) with a concurrencyLevel of 1.
ConcurrentIdentityHashMap(int, float, int) - Constructor for class alluxio.collections.ConcurrentIdentityHashMap
Creates a new, empty map with an initial table size based on the given number of elements (initialCapacity), load factor (loadFactor), and number of expected concurrently updating threads (concurrencyLevel).
concurrentReadPart() - Method in class alluxio.PositionReaderTest
Tests concurrently read from position reader.
CONF_DIR - Static variable in class alluxio.conf.PropertyKey
 
CONF_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
CONF_DYNAMIC_UPDATE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
CONF_DYNAMIC_UPDATE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
CONF_REGEX - Static variable in class alluxio.conf.PropertyKey
Regex to find ${key} for variable substitution.
CONF_VALIDATION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
CONF_VALIDATION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
ConfigCheckReport - Class in alluxio.wire
Represents a configuration report which records the configuration checker results.
ConfigCheckReport() - Constructor for class alluxio.wire.ConfigCheckReport
Creates a new instance of ConfigCheckReport.
ConfigCheckReport(ConfigCheckReport) - Constructor for class alluxio.wire.ConfigCheckReport
Creates a new instance of ConfigCheckReport from a proto representation.
ConfigCheckReport(Map<Scope, List<InconsistentProperty>>, Map<Scope, List<InconsistentProperty>>, ConfigStatus) - Constructor for class alluxio.wire.ConfigCheckReport
Creates a new instance of ConfigCheckReport.
ConfigHash - Class in alluxio.wire
Hashes of cluster and path level configurations.
ConfigHash(String, String) - Constructor for class alluxio.wire.ConfigHash
Constructs a new ConfigHash.
Configuration - Class in alluxio.conf
Global configuration properties of Alluxio.
Configuration - Class in alluxio.wire
Represents cluster level and path level configuration returned by meta master.
Configuration.Builder - Class in alluxio.wire
Configuration builder.
ConfigurationUtils - Class in alluxio.util
Utilities for working with Alluxio configurations.
ConfigurationValueOptions - Class in alluxio.conf
Options for getting configuration values.
connect() - Method in class alluxio.AbstractClient
Connects with the remote.
connect() - Method in interface alluxio.Client
Connects with the remote.
CONNECT_FROM_MASTER - alluxio.metrics.MetricInfo.UfsOps
 
CONNECT_FROM_WORKER - alluxio.metrics.MetricInfo.UfsOps
 
connectFromMaster(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
connectFromMaster(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
connectFromMaster(String) - Method in interface alluxio.underfs.UnderFileSystem
Takes any necessary actions required to establish a connection to the under file system from the given master host e.g.
connectFromMaster(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
connectFromWorker(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
connectFromWorker(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
connectFromWorker(String) - Method in interface alluxio.underfs.UnderFileSystem
Takes any necessary actions required to establish a connection to the under file system from the given worker host e.g.
connectFromWorker(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
ConnectionFailedException - Exception in alluxio.exception
Exception used when a network connection failure occurs.
ConnectionFailedException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.ConnectionFailedException
Constructs a new exception with the specified exception message and multiple parameters.
ConnectionFailedException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.ConnectionFailedException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
ConnectionFailedException(String) - Constructor for exception alluxio.exception.ConnectionFailedException
Constructs a new exception with the specified detail message.
ConnectionFailedException(String, Throwable) - Constructor for exception alluxio.exception.ConnectionFailedException
Constructs a new exception with the specified detail message and cause.
connectWithRuntimeException() - Method in class alluxio.AbstractClient
Connects with the remote server.
ConsistentUnderFileSystem - Class in alluxio.underfs
Represents a consistent under filesystem which does not have eventual consistency issues.
ConsistentUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.ConsistentUnderFileSystem
Creates a new ConsistentUnderFileSystem for the given uri.
ConsoleSink - Class in alluxio.metrics.sink
A sink which outputs metric values to the console.
ConsoleSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.ConsoleSink
Creates a new ConsoleSink with a Properties and MetricRegistry.
constantExecutorServiceFactory(ExecutorService) - Static method in class alluxio.util.executor.ExecutorServiceFactories
 
Constants - Class in alluxio
System wide constants.
contains(IndexDefinition<T, V>, V) - Method in class alluxio.collections.IndexedSet
Whether there is an object with the specified index field value in the set.
contains(Scope, Scope) - Static method in class alluxio.grpc.GrpcUtils
 
contains(AclAction) - Method in class alluxio.security.authorization.AclActions
 
contains(Object) - Method in class alluxio.collections.ConcurrentHashSet
 
contains(Object) - Method in class alluxio.collections.DelegatingSet
 
contains(Object) - Method in class alluxio.collections.UnmodifiableArrayList
 
contains(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Checks if a node with the given payload is in the DAG.
containsAll(Collection<?>) - Method in class alluxio.collections.ConcurrentHashSet
 
containsAll(Collection<?>) - Method in class alluxio.collections.DelegatingSet
 
containsAll(Collection<?>) - Method in class alluxio.collections.UnmodifiableArrayList
 
containsField(V) - Method in interface alluxio.collections.FieldIndex
Returns whether there is an object with the specified index field value in the set.
containsField(V) - Method in class alluxio.collections.NonUniqueFieldIndex
 
containsField(V) - Method in class alluxio.collections.UniqueFieldIndex
 
containsInterruptedException(Throwable) - Static method in class alluxio.util.ExceptionUtils
 
containsKey(Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
containsKey(K) - Method in class alluxio.collections.LockPool
Returns whether the pool contains a particular key.
containsLocalIp(List<InetSocketAddress>, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
 
containsObject(T) - Method in interface alluxio.collections.FieldIndex
Returns whether there is an object in the set.
containsObject(T) - Method in class alluxio.collections.NonUniqueFieldIndex
 
containsObject(T) - Method in class alluxio.collections.UniqueFieldIndex
 
containsValue(Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
containsWildcard() - Method in class alluxio.AlluxioURI
Whether or not the AlluxioURI contains wildcard(s).
CONTENT_HASH - alluxio.underfs.Fingerprint.Tag
 
ControllableQueue<T> - Class in alluxio.util.executor
A controllable queue is a priority queue with ControllableQueue.DelayNodes.
ControllableQueue() - Constructor for class alluxio.util.executor.ControllableQueue
Constructs a new ControllableQueue.
ControllableQueue.DelayNode<T> - Class in alluxio.util.executor
A delay node in delta queue which records the value and the total delay (which is the original delay plus the past time).
ControllableScheduler - Class in alluxio.util.executor
A controllable scheduler supports jump to a future time and run all commands within that time period.
ControllableScheduler() - Constructor for class alluxio.util.executor.ControllableScheduler
 
convertAclToStringEntries() - Method in class alluxio.wire.FileInfo
 
convertByteArrayToStringWithoutEscape(byte[], int, int) - Static method in class alluxio.util.webui.WebUtils
Converts a byte array to string.
convertDefaultAclToStringEntries() - Method in class alluxio.wire.FileInfo
 
convertFromByteString(Map<String, ByteString>) - Static method in class alluxio.util.CommonUtils
 
convertMsToClockTime(long) - Static method in class alluxio.util.CommonUtils
Converts milliseconds to clock time.
convertMsToDate(long, String) - Static method in class alluxio.util.CommonUtils
Converts a millisecond number to a formatted date String.
convertResults(List<ValidationTaskResult>) - Static method in interface alluxio.cli.ValidationTool
Converts the results of the ValidationTool.runAllTests() method into a map for digestion by other components.
convertToByteString(Map<String, byte[]>) - Static method in class alluxio.util.CommonUtils
 
convertToFolderName(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Appends the directory suffix to the key.
convertToNames(UfsStatus[]) - Static method in class alluxio.underfs.UfsStatus
Converts an array of UFS file status to a listing result where each element in the array is a file or directory name.
copy() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is completed normally with the same value as this CompletableFuture when it completes normally.
copy() - Method in class alluxio.conf.AlluxioProperties
Makes a copy of the backing properties and returns them in a new object.
copy() - Method in class alluxio.underfs.UfsDirectoryStatus
 
copy() - Method in class alluxio.underfs.UfsFileStatus
 
copy() - Method in class alluxio.underfs.UfsStatus
Create a copy of UfsStatus.
copy(List<Route>, UfsReadOptions, WriteOptions) - Method in interface alluxio.worker.dora.DoraWorker
Copies files from src to dst.
copyGlobal() - Static method in class alluxio.conf.Configuration
 
CopyJobRequest - Class in alluxio.job
The request of loading files.
CopyJobRequest(String, String, CopyJobPOptions) - Constructor for class alluxio.job.CopyJobRequest
 
copyObject(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Copies an object to another key.
copyProperties() - Method in interface alluxio.conf.AlluxioConfiguration
Gets a copy of the AlluxioProperties which back the AlluxioConfiguration.
copyProperties() - Static method in class alluxio.conf.Configuration
Create and return a copy of all properties.
copyProperties() - Method in class alluxio.conf.InstancedConfiguration
 
copyProperties() - Method in class alluxio.conf.path.SpecificPathConfiguration
 
copyProperties() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
COS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
 
COS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
COS_APP_ID - Static variable in class alluxio.conf.PropertyKey
 
COS_APP_ID - Static variable in class alluxio.conf.PropertyKey.Name
 
COS_CONNECTION_MAX - Static variable in class alluxio.conf.PropertyKey
 
COS_CONNECTION_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
COS_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
COS_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
COS_REGION - Static variable in class alluxio.conf.PropertyKey
 
COS_REGION - Static variable in class alluxio.conf.PropertyKey.Name
 
COS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
 
COS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
COS_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
COS_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
CountedCompleter<T> - Class in alluxio.concurrent.jsr
A ForkJoinTask with a completion action performed when triggered and there are no remaining pending actions.
CountedCompleter() - Constructor for class alluxio.concurrent.jsr.CountedCompleter
Creates a new CountedCompleter with no completer and an initial pending count of zero.
CountedCompleter(CountedCompleter<?>) - Constructor for class alluxio.concurrent.jsr.CountedCompleter
Creates a new CountedCompleter with the given completer and an initial pending count of zero.
CountedCompleter(CountedCompleter<?>, int) - Constructor for class alluxio.concurrent.jsr.CountedCompleter
Creates a new CountedCompleter with the given completer and initial pending count.
counter(String) - Static method in class alluxio.metrics.MetricsSystem
Get or add counter with the given name.
counterWithTags(String, boolean, String...) - Static method in class alluxio.metrics.MetricsSystem
Get or add counter with the given name with tags.
CountingLatch - Class in alluxio.concurrent
Similar to CountDownLatch except that the count can either be increased or decreased.
CountingLatch() - Constructor for class alluxio.concurrent.CountingLatch
 
CountingRetry - Class in alluxio.retry
An option which allows retrying based on maximum count.
CountingRetry(int) - Constructor for class alluxio.retry.CountingRetry
Constructs a retry facility which allows max number of retries.
crashed() - Method in class alluxio.thread.AutopsyThread
Checks if the thread has crashed.
create() - Static method in class alluxio.ClientContext
 
create() - Method in interface alluxio.util.executor.ExecutorServiceFactory
 
create(AlluxioConfiguration) - Static method in class alluxio.ClientContext
 
create(AlluxioConfiguration) - Static method in class alluxio.security.user.UserState.Factory
 
create(AlluxioConfiguration) - Static method in class alluxio.util.network.tls.SslContextProvider.Factory
Creates and initializes SslContextProvider implementation based on Alluxio configuration.
create(AlluxioConfiguration, UserState) - Static method in class alluxio.master.MasterInquireClient.Factory
 
create(AlluxioConfiguration, Subject) - Static method in class alluxio.security.user.UserState.Factory
 
create(AlluxioConfiguration, Subject, CommonUtils.ProcessType) - Static method in class alluxio.security.user.UserState.Factory
 
create(AuthType, AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticationProvider.Factory
 
create(URI, URI) - Static method in class alluxio.uri.URI.Factory
Resolves a child URI against a parent URI.
create(URI, String, boolean) - Static method in class alluxio.uri.URI.Factory
 
create(String) - Static method in class alluxio.client.quota.CacheScope
 
create(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
create(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
create(String) - Method in interface alluxio.underfs.UnderFileSystem
Creates a file in the under file system with the indicated name.
create(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
create(String) - Static method in class alluxio.uri.URI.Factory
Creates a URI from a string.
create(String, AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystem.Factory
Creates the UnderFileSystem instance according to its UFS path.
create(String, CreateOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
create(String, CreateOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
create(String, CreateOptions) - Method in interface alluxio.underfs.UnderFileSystem
Creates a file in the under file system with the specified CreateOptions.
create(String, CreateOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
create(String, UfsStatus) - Static method in class alluxio.underfs.Fingerprint
Parses the input string and returns the fingerprint object.
create(String, UfsStatus, AccessControlList) - Static method in class alluxio.underfs.Fingerprint
Parses the input string and returns the fingerprint object.
create(String, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.UnderFileSystem.Factory
Creates a client for operations involved with the under file system.
create(String, UnderFileSystemConfiguration) - Method in interface alluxio.underfs.UnderFileSystemFactory
Creates a new client for accessing the given path.
create(String, Authority, String, String) - Static method in class alluxio.uri.URI.Factory
Creates a URI from components.
create(String, SocketAddress) - Static method in class alluxio.grpc.GrpcServerAddress
 
create(String, Map<Object, Object>) - Method in class alluxio.cli.ValidationToolRegistry
Creates a new instance of ValidationTool.
create(String, S) - Method in interface alluxio.extensions.ExtensionFactory
Creates a new extension for the given path.
create(InetSocketAddress) - Static method in class alluxio.grpc.GrpcServerAddress
 
create(Iterator<? extends T>, Consumer<Void>) - Static method in class alluxio.resource.CloseableIterator
Wrap around an iterator with a resource to close.
create(Map<Object, Object>) - Method in interface alluxio.cli.ValidationToolFactory
Creates a new instance of ValidationTool.
create(Map<String, AlluxioConfiguration>) - Static method in interface alluxio.conf.path.PathConfiguration
Factory method to create an implementation of PathConfiguration.
create(Subject, AlluxioConfiguration) - Static method in class alluxio.ClientContext
A client context with information about the subject and configuration of the client.
create(Subject, AlluxioConfiguration, boolean) - Method in class alluxio.security.user.NoopUserState.Factory
 
create(Subject, AlluxioConfiguration, boolean) - Method in class alluxio.security.user.SimpleUserState.Factory
 
create(Subject, AlluxioConfiguration, boolean) - Method in interface alluxio.security.user.UserStateFactory
 
CREATE - alluxio.metrics.MetricInfo.UfsOps
 
createBlock(long, long, int, CreateBlockOptions) - Method in interface alluxio.worker.block.BlockStore
Creates a block in Alluxio managed space.
createBlock(long, long, int, CreateBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
Creates a block in Alluxio managed space.
createBlockId(long, long) - Static method in class alluxio.master.block.BlockId
 
CreateBlockOptions - Class in alluxio.worker.block
Method options for create a block.
CreateBlockOptions(String, String, long) - Constructor for class alluxio.worker.block.CreateBlockOptions
Constructor.
createBlockPath(String, String) - Static method in class alluxio.util.io.FileUtils
Creates the local block path and all the parent directories.
createBlockReader(long, long, long) - Method in interface alluxio.worker.block.BlockStore
Creates a reader of an existing block to read data from this block.
createBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockStore
Creates the block reader to read from Alluxio block or UFS block.
createBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
Creates the block reader to read from Alluxio block or UFS block.
createBlockReader(long, BlockMeta, long) - Method in interface alluxio.worker.block.BlockReaderFactory
 
createBlockRemote(long, long, String, long) - Method in interface alluxio.worker.block.BlockWorker
Creates a block.
createBlockWriter(long, long) - Method in interface alluxio.worker.block.BlockStore
Creates a BlockWriter for an existing temporary block which is already created by BlockStore.createBlock(long, long, int, alluxio.worker.block.CreateBlockOptions).
createBlockWriter(long, long) - Method in interface alluxio.worker.block.BlockWorker
Creates a BlockWriter for an existing temporary block which is already created by BlockWorker.createBlock(long, long, int, alluxio.worker.block.CreateBlockOptions).
createBlockWriter(TempBlockMeta) - Method in interface alluxio.worker.block.BlockWriterFactory
 
createCancelResponse() - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates a response in CANCELLED state.
createClientBootstrap(SocketAddress) - Static method in class alluxio.network.netty.NettyClient
Creates and returns a new Netty client bootstrap for clients to connect to remote servers.
createCloseableIterator(RocksIterator, RocksUtils.RocksIteratorParser<T>) - Static method in class alluxio.master.metastore.rocks.RocksUtils
Used to wrap an CloseableIterator over RocksIterator.
createDir(String) - Static method in class alluxio.util.io.FileUtils
Creates an empty directory and its intermediate directories if necessary.
createDirect(String, CreateOptions) - Method in interface alluxio.underfs.AtomicFileOutputStreamCallback
Creates a file in the under file system with the specified CreateOptions.
createEmptyObject(String) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
createEmptyObject(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Creates a zero-byte object used to encode a directory.
createEventLoop(ChannelType, int, String, boolean) - Static method in class alluxio.util.network.NettyUtils
Creates a Netty EventLoopGroup based on ChannelType.
createFile(String) - Static method in class alluxio.util.io.FileUtils
Creates an empty file and its intermediate directories if necessary.
createFileId(long) - Static method in class alluxio.util.IdUtils
Creates an id for a file based on the given id of the container.
createFileReader(String, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.dora.DoraWorker
Creates the file reader to read from Alluxio dora.
createFileSystemContextId() - Static method in class alluxio.util.IdUtils
 
createForAddresses(List<InetSocketAddress>, AlluxioConfiguration, UserState) - Static method in class alluxio.master.MasterInquireClient.Factory
 
createForJobMaster(AlluxioConfiguration, UserState) - Static method in class alluxio.master.MasterInquireClient.Factory
 
createForRoot(AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystem.Factory
 
createFrameDecoder() - Static method in class alluxio.network.protocol.RPCMessage
Creates a decoder that splits up the incoming ByteBuf into new ByteBuf's according to a length field in the input.
createFullAccess() - Static method in class alluxio.security.authorization.Mode
Creates the "full access" mode.
createInternalSessionId() - Static method in class alluxio.Sessions
 
createLoginContext(AuthType, Subject, ClassLoader, Configuration, CallbackHandler) - Static method in class alluxio.util.SecurityUtils
Creates a new LoginContext with the correct class loader.
createMountId() - Static method in class alluxio.util.IdUtils
 
createMountSpecificConf(Map<String, ? extends Object>) - Method in class alluxio.underfs.UnderFileSystemConfiguration
Creates a new instance from the current configuration and adds in new properties.
createNewClassInstance(Class<T>, Class<?>[], Object[]) - Static method in class alluxio.util.CommonUtils
Creates new instance of a class by calling a constructor that receives ctorClassArgs arguments.
createNewPath(String, boolean) - Method in class alluxio.uri.MultiPartSchemeURI
 
createNewPath(String, boolean) - Method in class alluxio.uri.StandardURI
 
createNewPath(String, boolean) - Method in interface alluxio.uri.URI
 
createNewResource() - Method in class alluxio.network.netty.NettyChannelPool
Creates a netty channel instance.
createNewResource() - Method in class alluxio.resource.DynamicResourcePool
Creates a new resource.
createNewResource() - Method in class alluxio.resource.ResourcePool
Creates a new resource which will be added to the resource pool after the user is done using it.
createNoAccess() - Static method in class alluxio.security.authorization.Mode
Creates the "no access" mode.
createNonexistingFile(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
createNonexistingFile(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
createNonexistingFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
createNonexistingFile(String) - Method in interface alluxio.underfs.UnderFileSystem
Creates a file in the under file system with the indicated name.
createNonexistingFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
createNonexistingFile(String, CreateOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
createNonexistingFile(String, CreateOptions) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
createNonexistingFile(String, CreateOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
createNonexistingFile(String, CreateOptions) - Method in interface alluxio.underfs.UnderFileSystem
Creates a file in the under file system with the specified CreateOptions.
createNonexistingFile(String, CreateOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
createObject(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Creates an OutputStream for object uploads.
createOkResponse(DataBuffer) - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates an OK response with data.
CreateOptions - Class in alluxio.underfs.options
Method options for creating a file in UnderFileSystem.
createOrGetAppIdFromConfig(AlluxioConfiguration) - Static method in class alluxio.util.IdUtils
 
createProgressThread(long, PrintStream) - Static method in class alluxio.util.CommonUtils
Creates a thread which will write "." to the given print stream at the given interval.
createProgressThread(PrintStream) - Static method in class alluxio.util.CommonUtils
Convenience method for calling CommonUtils.createProgressThread(long, PrintStream) with an interval of 2 seconds.
createResponse(AlluxioStatusException) - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates a response for a given AlluxioStatusException.
createResponse(Status, String, DataBuffer) - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates a response for a given status, message, and data buffer.
createRpcId() - Static method in class alluxio.util.IdUtils
 
createSaslHandler(ChannelAuthenticationScheme) - Method in interface alluxio.security.authentication.AuthenticationServer
Creates server-side Sasl handler for given scheme.
createSaslHandler(ChannelAuthenticationScheme) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
createSaslServer(String, String, String, Map<String, ?>, CallbackHandler) - Method in class alluxio.security.authentication.plain.PlainSaslServer.Factory
Creates a SaslServer using the parameters supplied.
createSessionId() - Static method in class alluxio.util.IdUtils
 
createStorageDirPath(String, String) - Static method in class alluxio.util.io.FileUtils
Creates the storage directory path, including any necessary but nonexistent parent directories.
createStream(long, long) - Method in class alluxio.underfs.MultiRangeObjectInputStream
Opens a new stream reading a range.
createTempBlockMeta(long, long, long) - Method in interface alluxio.worker.block.meta.DirView
Creates a TempBlockMeta given sessionId, blockId, and initialBlockSize.
createTempBlockMeta(long, long, long, DirView) - Method in interface alluxio.worker.block.TempBlockMetaFactory
 
createUfsBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockStore
Creates a block reader to read a UFS block starting from given block offset.
createUfsBlockReader(long, long, long, boolean, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
Creates a block reader to read a UFS block starting from given block offset.
createWithRecorder(String, UnderFileSystemConfiguration, Recorder) - Static method in class alluxio.underfs.UnderFileSystem.Factory
Creates a client for operations involved with the under file system and record the execution process.
CredentialPropertyKeys - Class in alluxio.conf
This class stores names of property keys whose values are credential.
CredentialPropertyKeys() - Constructor for class alluxio.conf.CredentialPropertyKeys
 
CREDENTIALS - alluxio.conf.PropertyKey.DisplayType
The property value contains credentials and should not be displayed directly.
CsvSink - Class in alluxio.metrics.sink
A sink which creates a CSV file of the metric values.
CsvSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.CsvSink
Creates a new CsvSink with a Properties and MetricRegistry.
CUR_DIR - Static variable in class alluxio.AlluxioURI
 
CurrentUser - Class in alluxio.security
This class represents the current user, which represents the end user.
CurrentUser(String) - Constructor for class alluxio.security.CurrentUser
Constructs a new user with a name.
CurrentUser(String, String) - Constructor for class alluxio.security.CurrentUser
Constructs a new user with a name and a service name.
CUSTOM - alluxio.security.authentication.AuthType
User is aware in Alluxio.
CUSTOM_EXCEPTION_MESSAGE - Static variable in exception alluxio.exception.BusyException
 
CustomAuthenticationProvider - Class in alluxio.security.authentication.plain
An authentication provider implementation that allows AuthenticationProvider to be customized at configuration time.
CustomAuthenticationProvider(Class<?>) - Constructor for class alluxio.security.authentication.plain.CustomAuthenticationProvider
Constructs a new custom authentication provider.

D

DATABASE_CONFIG_NAME - Static variable in class alluxio.cli.ValidationConfig
 
DATABASE_DOES_NOT_EXIST - alluxio.exception.ExceptionMessage
 
DATABASE_OPTION_NAME - Static variable in class alluxio.cli.ValidationConfig
 
DataBlockIndexType - Enum in alluxio.master.metastore.rocks
DataBlockIndexType used in conjunction with BlockBasedTable.
DataBuffer - Interface in alluxio.network.protocol.databuffer
This interface is a simple wrapper for the optional data that an RPCMessage may have.
DataFileChannel - Class in alluxio.network.protocol.databuffer
A DataBuffer with the underlying data being a FileChannel.
DataFileChannel(File, long, long) - Constructor for class alluxio.network.protocol.databuffer.DataFileChannel
 
DataLossException - Exception in alluxio.exception.status
Exception indicating unrecoverable data loss or corruption.
DataLossException(String) - Constructor for exception alluxio.exception.status.DataLossException
 
DataLossException(String, Throwable) - Constructor for exception alluxio.exception.status.DataLossException
 
DataLossException(Throwable) - Constructor for exception alluxio.exception.status.DataLossException
 
DataMessage<T,​R> - Class in alluxio.grpc
A struct that carries a message with a data buffer.
DataMessage(T, R) - Constructor for class alluxio.grpc.DataMessage
 
DataMessageMarshaller<T> - Class in alluxio.grpc
Marshaller for data messages.
DataMessageMarshaller(MethodDescriptor.Marshaller<T>) - Constructor for class alluxio.grpc.DataMessageMarshaller
Creates a data marshaller.
DataMessageMarshallerProvider<ReqT,​ResT> - Class in alluxio.grpc
A provider of DataMessageMarshaller for a gRPC call.
DataMessageMarshallerProvider(DataMessageMarshaller<ReqT>, DataMessageMarshaller<ResT>) - Constructor for class alluxio.grpc.DataMessageMarshallerProvider
 
DataPoint(double) - Constructor for class alluxio.metrics.TimeSeries.DataPoint
Construct a new data point with the current time as the timestamp.
DATASIZE - alluxio.conf.PropertyKey.PropertyType
The Property's value represents a data size, stored as a Long in bytes.
dataSizeBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
DataWorker - Interface in alluxio.worker
A Worker for caching data.
DAY - Static variable in class alluxio.Constants
 
DAY_MS - Static variable in class alluxio.Constants
 
DeadlineExceededException - Exception in alluxio.exception.status
Exception indicating that an operation was cancelled (typically by the caller).
DeadlineExceededException(String) - Constructor for exception alluxio.exception.status.DeadlineExceededException
 
DeadlineExceededException(String, Throwable) - Constructor for exception alluxio.exception.status.DeadlineExceededException
 
DeadlineExceededException(Throwable) - Constructor for exception alluxio.exception.status.DeadlineExceededException
 
DeadlineExceededRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that an operation expired before completion.
DeadlineExceededRuntimeException(String) - Constructor for exception alluxio.exception.runtime.DeadlineExceededRuntimeException
Constructor.
DEAFULT_FUSE_MOUNT - Static variable in class alluxio.Constants
 
deallocate() - Method in class alluxio.network.protocol.databuffer.PooledDirectNioByteBuf
 
debug(String) - Method in class alluxio.util.logging.SamplingLogger
 
debug(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
debug(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
debug(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
debug(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
debug(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
DEBUG - Static variable in class alluxio.conf.PropertyKey
 
DEBUG - Static variable in class alluxio.conf.PropertyKey.Name
 
dec() - Method in class alluxio.concurrent.CountingLatch
Decreases the counter.
decode(byte[]) - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
Decode an object from a single byte string.
decode(ByteBuf) - Static method in enum alluxio.network.protocol.RPCMessage.Type
Returns the type represented by the id from the input ByteBuf.
decode(ByteBuf, ProtoMessage) - Static method in class alluxio.network.protocol.RPCProtoMessage
Decodes the message from a buffer.
decode(ChannelHandlerContext, ByteBuf, List<Object>) - Method in class alluxio.network.protocol.RPCMessageDecoder
 
decodeMessage(RPCMessage.Type, ByteBuf) - Static method in class alluxio.network.protocol.RPCMessage
Returns the message of message type 'type', decoded from the input ByteBuf.
decreaseUsageCount() - Method in class alluxio.worker.block.io.LocalFileBlockReader
decrease the file reader usage count.
decrementPendingCountUnlessZero() - Method in class alluxio.concurrent.jsr.CountedCompleter
If the pending count is nonzero, (atomically) decrements it.
DEFAULT - alluxio.conf.PropertyKey.DisplayType
The property value should be displayed normally.
DEFAULT - alluxio.conf.Source.Type
The default property value from PropertyKey on compile time.
DEFAULT - Static variable in class alluxio.conf.Source
 
DEFAULT_FILE_SYSTEM_MODE - Static variable in class alluxio.Constants
 
DEFAULT_FILE_SYSTEM_UMASK - Static variable in class alluxio.Constants
 
DEFAULT_PROPERTIES_FILE_DOES_NOT_EXIST - alluxio.exception.ExceptionMessage
 
DEFAULT_REGISTRY_GET_TIMEOUT_MS - Static variable in class alluxio.Constants
 
DefaultAccessControlList - Class in alluxio.security.authorization
Default Access control list for a directory.
DefaultAccessControlList() - Constructor for class alluxio.security.authorization.DefaultAccessControlList
Constructor to build a default ACL that is empty.
DefaultAccessControlList(AccessControlList) - Constructor for class alluxio.security.authorization.DefaultAccessControlList
Constructor to build a default ACL based on an access ACL.
DefaultAuthenticationServer - Class in alluxio.security.authentication
Default implementation of AuthenticationServer.
DefaultAuthenticationServer(String, AlluxioConfiguration) - Constructor for class alluxio.security.authentication.DefaultAuthenticationServer
Creates DefaultAuthenticationServer instance.
defaultClientRetry() - Static method in class alluxio.retry.RetryUtils
Gives a default ClientRetry based on config.
defaultExecutor() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns the default Executor used for async methods that do not specify an Executor.
defaultForkJoinWorkerThreadFactory - Static variable in class alluxio.concurrent.jsr.ForkJoinPool
Creates a new ForkJoinWorkerThread.
defaultKeys() - Static method in class alluxio.conf.PropertyKey
 
defaultOptions() - Static method in class alluxio.resource.DynamicResourcePool.Options
 
defaults() - Static method in class alluxio.client.file.CacheContext
 
defaults() - Static method in class alluxio.conf.ConfigurationValueOptions
 
defaults() - Static method in class alluxio.network.netty.NettyRPCContext
 
defaults() - Static method in class alluxio.security.authorization.Mode
Gets the default mode.
defaults() - Static method in class alluxio.underfs.options.DeleteOptions
 
defaults() - Static method in class alluxio.underfs.options.FileLocationOptions
 
defaults() - Static method in class alluxio.underfs.options.ListOptions
 
defaults() - Static method in class alluxio.underfs.options.OpenOptions
 
defaults() - Static method in class alluxio.util.WaitForOptions
 
defaults(AlluxioConfiguration) - Static method in class alluxio.underfs.options.CreateOptions
 
defaults(AlluxioConfiguration) - Static method in class alluxio.underfs.options.MkdirsOptions
 
defaults(AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystemConfiguration
 
DefaultSslContextProvider - Class in alluxio.util.network.tls
Default SSL context provider.
DefaultSslContextProvider() - Constructor for class alluxio.util.network.tls.DefaultSslContextProvider
 
DefaultSupplier - Class in alluxio
Supplier for a configuration property default.
DefaultSupplier(Supplier<Object>, String) - Constructor for class alluxio.DefaultSupplier
 
defaultWorkerMasterClientRetry() - Static method in class alluxio.retry.RetryUtils
 
delayedExecutor(long, TimeUnit) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new Executor that submits a task to the default executor after the given delay (or no delay if non-positive).
delayedExecutor(long, TimeUnit, Executor) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new Executor that submits a task to the given base executor after the given delay (or no delay if non-positive).
DelayNode(T, long) - Constructor for class alluxio.util.executor.ControllableQueue.DelayNode
Constructs a new ControllableQueue.DelayNode.
DelegatingBlockReader - Class in alluxio.worker.block.io
An delegating reader class.
DelegatingBlockReader(BlockReader, Closeable) - Constructor for class alluxio.worker.block.io.DelegatingBlockReader
Default constructor for the abstract reader implementations.
DelegatingSet<T> - Class in alluxio.collections
A set which delegates all methods to another set.
DelegatingSet(Set<T>) - Constructor for class alluxio.collections.DelegatingSet
 
delete(String) - Static method in class alluxio.util.io.FileUtils
Deletes the file or directory.
DELETE - alluxio.wire.CommandType
Ask worker to delete files.
DELETE_DIRECTORY - alluxio.metrics.MetricInfo.UfsOps
 
DELETE_FILE - alluxio.metrics.MetricInfo.UfsOps
 
DELETE_NONEMPTY_DIRECTORY_NONRECURSIVE - alluxio.exception.ExceptionMessage
 
DELETE_ROOT_DIRECTORY - alluxio.exception.ExceptionMessage
 
DeleteBuffer() - Constructor for class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer
Construct a new ObjectUnderFileSystem.DeleteBuffer instance.
deleteDirectory(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
deleteDirectory(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
deleteDirectory(String) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a directory from the under file system with the indicated name non-recursively.
deleteDirectory(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
deleteDirectory(String, DeleteOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
deleteDirectory(String, DeleteOptions) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a directory from the under file system with the indicated name.
deleteDirectory(String, DeleteOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteDirIfExists(UnderFileSystem, String) - Static method in class alluxio.util.UnderFileSystemUtils
Deletes the directory at the given path if it exists.
deleteExistingDirectory(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
deleteExistingDirectory(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
deleteExistingDirectory(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
deleteExistingDirectory(String) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a directory from the under file system.
deleteExistingDirectory(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteExistingDirectory(String, DeleteOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
deleteExistingDirectory(String, DeleteOptions) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
deleteExistingDirectory(String, DeleteOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
deleteExistingDirectory(String, DeleteOptions) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a directory from the under file system with the indicated name.
deleteExistingDirectory(String, DeleteOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteExistingFile(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
deleteExistingFile(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
deleteExistingFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
deleteExistingFile(String) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a file from the under file system with the indicated name.
deleteExistingFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteFile(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
deleteFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
deleteFile(String) - Method in interface alluxio.underfs.UnderFileSystem
Deletes a file from the under file system with the indicated name.
deleteFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
deleteFileIfExists(UnderFileSystem, String) - Static method in class alluxio.util.UnderFileSystemUtils
Deletes the specified path from the specified under file system if it is a file and exists.
deleteIf(String, Function<TrieNode<V>, Boolean>) - Method in class alluxio.conf.path.TrieNode
Deletes the path from the Trie if the given predicate is true.
deleteLeaf(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Deletes a leaf DAG node that carries the given payload.
deleteObject(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Internal function to delete a key.
deleteObjects(List<String>) - Method in class alluxio.underfs.ObjectUnderFileSystem
Internal function to delete a list of keys.
DeleteOptions - Class in alluxio.underfs.options
Method options for deleting a directory in UnderFileSystem.
deletePathRecursively(String) - Static method in class alluxio.util.io.FileUtils
Deletes a file or a directory, recursively if it is a directory.
Deprecated - Annotation Type in alluxio.conf
An annotation for PropertyKeys that can be used to mark a key as deprecated (slated for removal).
DeprecatedKeyChecker - Class in alluxio.conf
This annotation checker should be used to determine whether a PropertyKey or PropertyKey.Template has a given annotation.
DeprecatedKeyChecker() - Constructor for class alluxio.conf.DeprecatedKeyChecker
Create a new instance of DeprecatedKeyChecker.
DescendantType - Enum in alluxio.file.options
Type of descendant level processing for filesystem inodes.
deserialize(JsonParser, DeserializationContext) - Method in class alluxio.security.authorization.AccessControlList.AccessControlListDeserializer
Deserialize an AccessControlList object.
deserialize(ReadableBuffer) - Method in class alluxio.grpc.DataMessageMarshaller
Deserialize data buffer to the message.
deserialize(ReadableBuffer) - Method in class alluxio.grpc.ReadResponseMarshaller
 
deserialize(ReadableBuffer) - Method in class alluxio.grpc.WriteRequestMarshaller
 
DESTINATION_CANNOT_BE_FILE - alluxio.exception.ExceptionMessage
 
DFS - alluxio.master.file.MetadataSyncTraversalOrder
 
dir() - Method in class alluxio.worker.block.BlockStoreLocation
Gets the directory index of the location.
DIRECT_BUFFER_POOL - Static variable in class alluxio.metrics.MetricsSystem
 
DirectedAcyclicGraph<T> - Class in alluxio.collections
A Directed Acyclic Graph (DAG).
DirectedAcyclicGraph() - Constructor for class alluxio.collections.DirectedAcyclicGraph
A Directed Acyclic Graph (DAG).
DirectedAcyclicGraphNode<T> - Class in alluxio.collections
A Directed Acyclic Graph (DAG) node.
DirectedAcyclicGraphNode(T) - Constructor for class alluxio.collections.DirectedAcyclicGraphNode
A Directed Acyclic Graph (DAG) node.
DirectedAcyclicGraphNode(T, List<DirectedAcyclicGraphNode<T>>, List<DirectedAcyclicGraphNode<T>>) - Constructor for class alluxio.collections.DirectedAcyclicGraphNode
A Directed Acyclic Graph (DAG) node.
DIRECTORY - alluxio.underfs.Fingerprint.Type
 
DIRECTORY - alluxio.worker.block.management.BackoffStrategy
 
DirectoryNotEmptyException - Exception in alluxio.exception
Exception for situations where an operation fails because a directory is not empty.
DirectoryNotEmptyException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.DirectoryNotEmptyException
Constructs a new exception with the specified exception message and multiple parameters.
DirectoryNotEmptyException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.DirectoryNotEmptyException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
DirectoryNotEmptyException(String) - Constructor for exception alluxio.exception.DirectoryNotEmptyException
Constructs a new exception with the specified detail message.
DirectoryNotEmptyException(String, Throwable) - Constructor for exception alluxio.exception.DirectoryNotEmptyException
Constructs a new exception with the specified detail message and cause.
DirView - Interface in alluxio.worker.block.meta
A view of StorageDir to provide more limited access.
disableAuthentication() - Method in class alluxio.grpc.GrpcChannelBuilder
Disables authentication with the server.
disableAuthentication() - Method in class alluxio.grpc.GrpcService
If called, clients can access this service's methods without authentication.
disableAutoRead(Channel) - Static method in class alluxio.util.network.NettyUtils
Disables auto read for a netty channel.
disconnect() - Method in class alluxio.AbstractClient
 
disconnect() - Method in interface alluxio.Client
Closes the connection with the Alluxio remote and does the necessary cleanup.
dispose() - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
DORA_CLIENT_METADATA_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
DORA_CLIENT_METADATA_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_CLIENT_READ_LOCATION_POLICY_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
DORA_CLIENT_READ_LOCATION_POLICY_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_CLIENT_UFS_ROOT - Static variable in class alluxio.conf.PropertyKey
 
DORA_CLIENT_UFS_ROOT - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_UFS_FILE_STATUS_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
DORA_UFS_FILE_STATUS_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_UFS_FILE_STATUS_CACHE_TTL - Static variable in class alluxio.conf.PropertyKey
 
DORA_UFS_FILE_STATUS_CACHE_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_UFS_LIST_STATUS_CACHE_NR_DIRS - Static variable in class alluxio.conf.PropertyKey
 
DORA_UFS_LIST_STATUS_CACHE_NR_DIRS - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_UFS_LIST_STATUS_CACHE_TTL - Static variable in class alluxio.conf.PropertyKey
 
DORA_UFS_LIST_STATUS_CACHE_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_WORKER_METASTORE_ROCKSDB_DIR - Static variable in class alluxio.conf.PropertyKey
 
DORA_WORKER_METASTORE_ROCKSDB_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
DORA_WORKER_METASTORE_ROCKSDB_TTL - Static variable in class alluxio.conf.PropertyKey
 
DORA_WORKER_METASTORE_ROCKSDB_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
DoraWorker - Interface in alluxio.worker.dora
A block worker in the Alluxio system.
DOUBLE - alluxio.conf.PropertyKey.PropertyType
The Property's value is of double type, stored as a Double.
doubleBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
downgrade() - Method in class alluxio.resource.RWLockResource
Downgrade from a write to a read lock.
drainTasksTo(Collection<? super ForkJoinTask<?>>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
Removes all available unexecuted submitted and forked tasks from scheduling queues and adds them to the given collection, without altering their execution status.
drainTo(Collection<? super T>) - Method in class alluxio.util.executor.UniqueBlockingQueue
 
drainTo(Collection<? super T>, int) - Method in class alluxio.util.executor.UniqueBlockingQueue
 
dropReference() - Method in class alluxio.concurrent.ClientRWLock
Decrements the reference count.
dumpMainInfo() - Method in class alluxio.wire.WorkerNetAddress
dump the main info of the WorkerNetAddress object.
DURATION - alluxio.conf.PropertyKey.PropertyType
The Property's value represents a time duration, stored as a Long in ms.
durationBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
DynamicResourcePool<T> - Class in alluxio.resource
A dynamic pool that manages the resources.
DynamicResourcePool(DynamicResourcePool.Options) - Constructor for class alluxio.resource.DynamicResourcePool
Creates a dynamic pool instance.
DynamicResourcePool.Options - Class in alluxio.resource
Options to initialize a Dynamic resource pool.
DynamicResourcePool.ResourceInternal<R> - Class in alluxio.resource
A wrapper on the resource to include the last time at which it was used.

E

ElapsedTimeClock - Class in alluxio.clock
A monotonically increasing clock for calculating elapsed time.
ElapsedTimeClock() - Constructor for class alluxio.clock.ElapsedTimeClock
 
EMBEDDED - alluxio.master.journal.JournalType
 
EmbeddedLogicalAuthority - Class in alluxio.uri
A logical host authority implementation.
EmbeddedLogicalAuthority(String) - Constructor for class alluxio.uri.EmbeddedLogicalAuthority
 
EMPTY_ACL - Static variable in class alluxio.security.authorization.AccessControlList
 
EMPTY_ACL - Static variable in class alluxio.underfs.BaseUnderFileSystem
 
EMPTY_CREATION_TIME - Static variable in class alluxio.util.webui.UIFileInfo.LocalFileInfo
The constant EMPTY_CREATION_TIME.
EMPTY_DEFAULT_ACL - Static variable in class alluxio.security.authorization.DefaultAccessControlList
 
EMPTY_FILE_INFO_LIST_FOR_PERMISSION_CHECK - alluxio.exception.PreconditionMessage
 
EMPTY_URI - Static variable in class alluxio.AlluxioURI
 
emptyConfig() - Static method in class alluxio.underfs.UnderFileSystemConfiguration
 
emptyInfo() - Static method in class alluxio.SyncInfo
Returns an empty SyncInfo object.
enableAutoRead(Channel) - Static method in class alluxio.util.network.NettyUtils
Enables auto read for a netty channel.
encode(ByteBuf) - Method in interface alluxio.network.protocol.EncodedMessage
Encodes the message to the output ByteBuf.
encode(ByteBuf) - Method in enum alluxio.network.protocol.RPCMessage.Type
 
encode(ByteBuf) - Method in class alluxio.network.protocol.RPCProtoMessage
 
encode(ChannelHandlerContext, RPCMessage, List<Object>) - Method in class alluxio.network.protocol.RPCMessageEncoder
 
encode(T) - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
Encode a single object into a byte string.
EncodedMessage - Interface in alluxio.network.protocol
Represents an encoded message.
ENFORCE - alluxio.conf.PropertyKey.ConsistencyCheckLevel
Check consistency of property value, show error of inconsistent values.
entrySet() - Method in class alluxio.collections.ConcurrentIdentityHashMap
Returns a set representing the entries of this map at the time of calling.
entrySet() - Method in class alluxio.conf.AlluxioProperties
 
ENUM - alluxio.conf.PropertyKey.PropertyType
The Property's value is an enum for a predefined enum class.
enumBuilder(String, Class<? extends Enum>) - Static method in class alluxio.conf.PropertyKey.Builder
 
EnvironmentUtils - Class in alluxio.util
Utilities to detect environment Alluxio is running in.
EPOLL - alluxio.network.ChannelType
Use Linux's epoll for channel API.
equalConstantByteArray(byte, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array starts with a constant sequence of bytes of the given value and length.
equalIncreasingByteArray(int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array starts with an increasing sequence of bytes of the given length, starting from 0.
equalIncreasingByteArray(int, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array starts with an increasing sequence of bytes of the given length, starting from the given value.
equalIncreasingByteBuf(int, int, ByteBuf) - Static method in class alluxio.util.io.BufferUtils
Checks if the given ByteBuf starts with an increasing sequence of bytes starting at the given value of length equal to or greater than the given length.
equalIncreasingByteBuffer(int, int, ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Checks if the given ByteBuffer starts with an increasing sequence of bytes starting at the given value of length equal to or greater than the given length.
equals(Object) - Method in class alluxio.AlluxioURI
 
equals(Object) - Method in class alluxio.client.file.CacheContext
 
equals(Object) - Method in class alluxio.client.file.URIStatus
 
equals(Object) - Method in class alluxio.client.hive.HiveCacheContext
 
equals(Object) - Method in class alluxio.client.quota.CacheQuota
 
equals(Object) - Method in class alluxio.client.quota.CacheScope
 
equals(Object) - Method in class alluxio.collections.DelegatingSet
 
equals(Object) - Method in class alluxio.collections.Pair
 
equals(Object) - Method in class alluxio.collections.TwoKeyConcurrentMap
The equals implementation for this map simply uses the superclass's equals.
equals(Object) - Method in class alluxio.conf.PropertyKey
 
equals(Object) - Method in class alluxio.conf.Source
 
equals(Object) - Method in class alluxio.grpc.GrpcChannel
 
equals(Object) - Method in class alluxio.grpc.GrpcChannelKey
 
equals(Object) - Method in class alluxio.grpc.GrpcServerAddress
 
equals(Object) - Method in class alluxio.job.JobDescription
 
equals(Object) - Method in interface alluxio.master.MasterInquireClient.ConnectDetails
 
equals(Object) - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
equals(Object) - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
equals(Object) - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
equals(Object) - Method in class alluxio.metrics.Metric
 
equals(Object) - Method in class alluxio.metrics.MetricKey
 
equals(Object) - Method in class alluxio.metrics.MetricsFilter
 
equals(Object) - Method in class alluxio.security.authorization.AccessControlList
 
equals(Object) - Method in class alluxio.security.authorization.AclActions
 
equals(Object) - Method in class alluxio.security.authorization.AclEntry
 
equals(Object) - Method in class alluxio.security.authorization.DefaultAccessControlList
 
equals(Object) - Method in class alluxio.security.authorization.ExtendedACLEntries
 
equals(Object) - Method in class alluxio.security.authorization.Mode
 
equals(Object) - Method in class alluxio.security.CurrentUser
 
equals(Object) - Method in class alluxio.security.user.BaseUserState
 
equals(Object) - Method in class alluxio.security.User
 
equals(Object) - Method in class alluxio.SessionInfo
 
equals(Object) - Method in class alluxio.underfs.options.CreateOptions
 
equals(Object) - Method in class alluxio.underfs.options.DeleteOptions
 
equals(Object) - Method in class alluxio.underfs.options.FileLocationOptions
 
equals(Object) - Method in class alluxio.underfs.options.ListOptions
 
equals(Object) - Method in class alluxio.underfs.options.MkdirsOptions
 
equals(Object) - Method in class alluxio.underfs.options.OpenOptions
 
equals(Object) - Method in class alluxio.underfs.UfsStatus
 
equals(Object) - Method in class alluxio.uri.EmbeddedLogicalAuthority
 
equals(Object) - Method in class alluxio.uri.MultiMasterAuthority
 
equals(Object) - Method in class alluxio.uri.MultiPartSchemeURI
 
equals(Object) - Method in class alluxio.uri.NoAuthority
 
equals(Object) - Method in class alluxio.uri.SingleMasterAuthority
 
equals(Object) - Method in class alluxio.uri.StandardURI
 
equals(Object) - Method in class alluxio.uri.UnknownAuthority
 
equals(Object) - Method in class alluxio.uri.ZookeeperAuthority
 
equals(Object) - Method in class alluxio.uri.ZookeeperLogicalAuthority
 
equals(Object) - Method in class alluxio.util.UnixMountInfo
 
equals(Object) - Method in class alluxio.util.UnixMountInfo.Options
 
equals(Object) - Method in class alluxio.util.WaitForOptions
 
equals(Object) - Method in class alluxio.util.webui.NodeInfo
 
equals(Object) - Method in class alluxio.wire.Address
 
equals(Object) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
equals(Object) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
equals(Object) - Method in class alluxio.wire.AlluxioMasterInfo
 
equals(Object) - Method in class alluxio.wire.AlluxioProxyInfo
 
equals(Object) - Method in class alluxio.wire.AlluxioWorkerInfo
 
equals(Object) - Method in class alluxio.wire.BlockInfo
 
equals(Object) - Method in class alluxio.wire.BlockLocation
 
equals(Object) - Method in class alluxio.wire.BlockMasterInfo
 
equals(Object) - Method in class alluxio.wire.Capacity
 
equals(Object) - Method in class alluxio.wire.ConfigHash
 
equals(Object) - Method in class alluxio.wire.FileBlockInfo
 
equals(Object) - Method in class alluxio.wire.FileInfo
 
equals(Object) - Method in class alluxio.wire.InconsistentProperty
 
equals(Object) - Method in class alluxio.wire.MasterInfo
 
equals(Object) - Method in class alluxio.wire.MountPointInfo
 
equals(Object) - Method in class alluxio.wire.TieredIdentity
 
equals(Object) - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
equals(Object) - Method in class alluxio.wire.WorkerInfo
 
equals(Object) - Method in class alluxio.wire.WorkerNetAddress
 
equals(Object) - Method in class alluxio.worker.block.AllocateOptions
 
equals(Object) - Method in class alluxio.worker.block.BlockStoreLocation
Compares to a specific object.
equals(Object) - Method in class alluxio.worker.block.CreateBlockOptions
 
equals(String, String) - Static method in class alluxio.util.URIUtils
Checks if two (nullable) strings are equal.
ERR_BUFFER_STATE - alluxio.exception.PreconditionMessage
 
ERR_READ_BUFFER_NULL - alluxio.exception.PreconditionMessage
 
ERR_SEEK_NEGATIVE - alluxio.exception.PreconditionMessage
 
ERR_SEEK_PAST_END_OF_FILE - alluxio.exception.PreconditionMessage
 
ERR_WRITE_BUFFER_NULL - alluxio.exception.PreconditionMessage
 
error(String) - Method in class alluxio.util.logging.SamplingLogger
 
error(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
error(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
error(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
error(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
error(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
escape(AlluxioURI) - Static method in class alluxio.metrics.MetricsSystem
Escapes a URI, replacing "/" with "%2F".
evaluateResponse(byte[]) - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
exceptionally(Function<Throwable, ? extends T>) - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is completed when this CompletableFuture completes, with the result of the given function of the exception triggering this CompletableFuture's completion when it completes exceptionally; otherwise, if this CompletableFuture completes normally, then the returned CompletableFuture also completes normally with the same value.
exceptionally(Function<Throwable, ? extends T>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes exceptionally, is executed with this stage's exception as the argument to the supplied function.
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class alluxio.network.netty.NettyRPC.RPCHandler
 
exceptionCaught(ChannelHandlerContext, Throwable) - Method in class alluxio.network.protocol.RPCMessageDecoder
 
ExceptionMessage - Enum in alluxio.exception
Exception messages used across Alluxio.
ExceptionUtils - Class in alluxio.util
Utility methods for working with exceptions.
exec() - Method in class alluxio.concurrent.jsr.CountedCompleter
Implements execution conventions for CountedCompleters.
exec() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Immediately performs the base action of this task and returns true if, upon return from this method, this task is guaranteed to have completed normally.
execCmdWithBackup(ShellCommand, ShellCommand) - Static method in class alluxio.util.ShellUtils
Executes a shell command.
execCommand(String...) - Static method in class alluxio.util.ShellUtils
Static method to execute a shell command.
execCommandWithOutput(String...) - Static method in class alluxio.util.ShellUtils
Static method to execute a shell command and tolerate non-zero exit code.
execute(ForkJoinTask<?>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
Arranges for (asynchronous) execution of the given task.
execute(Runnable) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
execute(Runnable) - Method in class alluxio.metrics.InstrumentedExecutorService
 
execute(Runnable) - Method in class alluxio.util.executor.ControllableScheduler
 
execute(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Convenience method for executing a heartbeat and waiting for it to complete.
EXECUTE - alluxio.security.authorization.AclAction
 
EXECUTE - alluxio.security.authorization.Mode.Bits
 
executor(Executor) - Method in class alluxio.grpc.GrpcServerBuilder
Set the executor for this server.
executorService(ExecutorService, String) - Static method in class alluxio.metrics.MetricsSystem
Add or replace the instrumented executor service metrics for the given name and executor service.
ExecutorServiceFactories - Class in alluxio.util.executor
Convenience methods for constructing instances of ExecutorServiceFactory.
ExecutorServiceFactory - Interface in alluxio.util.executor
Interface for a factory which constructs executor services.
ExecutorServiceUtils - Class in alluxio.util.executor
Util class for ExecutorService.
ExecutorServiceUtils() - Constructor for class alluxio.util.executor.ExecutorServiceUtils
 
exists(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
exists(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
exists(String) - Method in interface alluxio.underfs.UnderFileSystem
Checks if a file or directory exists in under file system.
exists(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
exists(String) - Static method in class alluxio.util.io.FileUtils
Checks if a path exists.
EXISTS - alluxio.metrics.MetricInfo.UfsOps
 
ExitCodeException(int, String) - Constructor for exception alluxio.util.ShellUtils.ExitCodeException
Constructs an ExitCodeException.
EXPIRED - alluxio.time.ExponentialTimer.Result
 
ExponentialBackoffRetry - Class in alluxio.retry
Each retry will cause a sleep to happen.
ExponentialBackoffRetry(int, int, int) - Constructor for class alluxio.retry.ExponentialBackoffRetry
Constructs a new retry facility which sleeps for an exponentially increasing amount of time between retries.
ExponentialTimeBoundedRetry - Class in alluxio.retry
A retry policy which uses exponential backoff and a maximum duration time bound.
ExponentialTimeBoundedRetry.Builder - Class in alluxio.retry
Builder for time bounded exponential retry mechanisms.
ExponentialTimer - Class in alluxio.time
The ExponentialTimer can be used for generating a sequence of events that are exponentially distributed in time.
ExponentialTimer(long, long, long, long) - Constructor for class alluxio.time.ExponentialTimer
Creates a new instance of ExponentialTimer.
ExponentialTimer.Result - Enum in alluxio.time
Represents the result of ExponentialTimer.tick().
ExtendedACLEntries - Class in alluxio.security.authorization
Stores the extended ACL entries.
ExtendedACLEntries() - Constructor for class alluxio.security.authorization.ExtendedACLEntries
Creates an empty extended ACL.
ExtendedACLEntries(ExtendedACLEntries) - Constructor for class alluxio.security.authorization.ExtendedACLEntries
Creates a copy.
ExtendedAttribute<T> - Interface in alluxio.master.file.meta.xattr
This class defines an interface for implementing an extended attribute which can be stored on inodes.
ExtendedAttribute.NamespacePrefix - Enum in alluxio.master.file.meta.xattr
The namespace for extended attributes.
EXTENSION_JAR - Static variable in class alluxio.Constants
 
ExtensionFactory<T,​S extends AlluxioConfiguration> - Interface in alluxio.extensions
A factory class for creating instance of ExtensionFactory based on configuration ExtensionFactory.
ExtensionFactoryRegistry<T extends ExtensionFactory<?,​S>,​S extends AlluxioConfiguration> - Class in alluxio.extensions
An extension registry that uses the ServiceLoader mechanism to automatically discover available factories and provides a central place for obtaining actual extension instances.
ExtensionFactoryRegistry(Class<T>, String) - Constructor for class alluxio.extensions.ExtensionFactoryRegistry
Constructs a registry for loading extension of a particular type.
EXTENSIONS_DIR - Static variable in class alluxio.conf.PropertyKey
 
EXTENSIONS_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
ExtensionsClassLoader - Class in alluxio.extensions
An isolated ClassLoader for loading extensions to core Alluxio.
ExtensionsClassLoader(URL[], ClassLoader) - Constructor for class alluxio.extensions.ExtensionsClassLoader
 
ExtensionUtils - Class in alluxio.util
Utility functions for working with extensions.
extractGroupBits(short) - Static method in class alluxio.security.authorization.Mode
 
extractOtherBits(short) - Static method in class alluxio.security.authorization.Mode
 
extractOwnerBits(short) - Static method in class alluxio.security.authorization.Mode
 

F

FACTORIES - Static variable in interface alluxio.security.user.UserState
An ordered list of factories for creating UserState instances.
Factory() - Constructor for class alluxio.master.selectionpolicy.MasterSelectionPolicy.Factory
 
Factory() - Constructor for class alluxio.security.authentication.plain.PlainSaslServer.Factory
Constructs a new PlainSaslServer.Factory for the PlainSaslServer.
Factory() - Constructor for class alluxio.security.user.NoopUserState.Factory
 
Factory() - Constructor for class alluxio.security.user.SimpleUserState.Factory
 
Factory() - Constructor for class alluxio.security.user.UserState.Factory
 
FAILED - alluxio.cli.ValidationUtils.State
 
FAILED_CACHE - alluxio.exception.ExceptionMessage
 
FAILED_COMMIT_BLOCK_TO_MASTER - alluxio.exception.ExceptionMessage
 
FAILED_UFS_RENAME - alluxio.exception.ExceptionMessage
 
failedFuture(Throwable) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is already completed exceptionally with the given exception.
FailedPreconditionException - Exception in alluxio.exception.status
Exception indicating that operation was rejected because the system is not in a state required for the operation's execution.
FailedPreconditionException(String) - Constructor for exception alluxio.exception.status.FailedPreconditionException
 
FailedPreconditionException(String, Throwable) - Constructor for exception alluxio.exception.status.FailedPreconditionException
 
FailedPreconditionException(Throwable) - Constructor for exception alluxio.exception.status.FailedPreconditionException
 
FailedPreconditionRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that operation was rejected because the system is not in a state required for the operation's execution.
FailedPreconditionRuntimeException(String) - Constructor for exception alluxio.exception.runtime.FailedPreconditionRuntimeException
Constructor.
FailedPreconditionRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.FailedPreconditionRuntimeException
Constructor.
FailedPreconditionRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.FailedPreconditionRuntimeException
Constructor.
failedStage(Throwable) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletionStage that is already completed exceptionally with the given exception and supports only those methods in interface CompletionStage.
FailedToAcquireRegisterLeaseException - Exception in alluxio.exception
The exception thrown when the worker cannot acquire a registration lease after all the retry attempts have been exhausted.
FailedToAcquireRegisterLeaseException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FailedToAcquireRegisterLeaseException
Constructs a new exception with the specified exception message and multiple parameters.
FailedToAcquireRegisterLeaseException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FailedToAcquireRegisterLeaseException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
FailedToAcquireRegisterLeaseException(String) - Constructor for exception alluxio.exception.FailedToAcquireRegisterLeaseException
Constructs a new exception with the specified detail message.
FailedToAcquireRegisterLeaseException(String, Throwable) - Constructor for exception alluxio.exception.FailedToAcquireRegisterLeaseException
Constructs a new exception with the specified detail message and cause.
fastCopy(ReadableByteChannel, WritableByteChannel) - Static method in class alluxio.util.io.BufferUtils
An efficient copy between two channels with a fixed-size buffer.
FeatureUtils - Class in alluxio.util
Utilities to detect features that Alluxio is running with.
FeatureUtils() - Constructor for class alluxio.util.FeatureUtils
 
FieldIndex<T,​V> - Interface in alluxio.collections
An interface representing an index for IndexedSet, each index for this set must implement the interface to define how to get the value of the field chosen as the index.
FILE - alluxio.underfs.Fingerprint.Type
 
FILE - alluxio.worker.block.BlockStoreType
The entire block is written to a single file.
FILE_DIR_PERMISSION_DIFF - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_JOB_SERVICE_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_JOB_SERVICE_VERSION - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_WORKER_SERVICE_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_MASTER_WORKER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
FILE_SYSTEM_WORKER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
FILE_SYSTEM_WORKER_NAME - Static variable in class alluxio.Constants
 
FileAlreadyCompletedException - Exception in alluxio.exception
The exception thrown when a file is already completed in Alluxio.
FileAlreadyCompletedException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FileAlreadyCompletedException
Constructs a new exception with the specified exception message and multiple parameters.
FileAlreadyCompletedException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FileAlreadyCompletedException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
FileAlreadyCompletedException(String) - Constructor for exception alluxio.exception.FileAlreadyCompletedException
Constructs a new exception with the specified detail message.
FileAlreadyCompletedException(String, Throwable) - Constructor for exception alluxio.exception.FileAlreadyCompletedException
Constructs a new exception with the specified detail message and cause.
FileAlreadyExistsException - Exception in alluxio.exception
The exception thrown when a file already exists in Alluxio.
FileAlreadyExistsException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception with the specified exception message and multiple parameters.
FileAlreadyExistsException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
FileAlreadyExistsException(String) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception with the specified detail message.
FileAlreadyExistsException(String, Throwable) - Constructor for exception alluxio.exception.FileAlreadyExistsException
Constructs a new exception with the specified detail message and cause.
FileBlockInfo - Class in alluxio.wire
The file block information.
FileBlockInfo() - Constructor for class alluxio.wire.FileBlockInfo
Creates a new instance of FileBlockInfo.
FileDoesNotExistException - Exception in alluxio.exception
The exception thrown when a path does not exist in Alluxio.
FileDoesNotExistException(AlluxioURI) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception stating that the given path does not exist.
FileDoesNotExistException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception with the specified exception message and multiple parameters.
FileDoesNotExistException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
FileDoesNotExistException(String) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception with the specified detail message.
FileDoesNotExistException(String, Throwable) - Constructor for exception alluxio.exception.FileDoesNotExistException
Constructs a new exception with the specified detail message and cause.
FileId - Class in alluxio.file
Opaque file identifiers, which are typically a long or a string-based ID.
fileIdFromBlockId(long) - Static method in class alluxio.util.IdUtils
Creates a file ID from a block ID.
FileIncompleteException - Exception in alluxio.exception
The exception thrown when opening a file that hasn't completed.
FileIncompleteException(AlluxioURI) - Constructor for exception alluxio.exception.FileIncompleteException
Constructs a new exception stating that the given file is incomplete.
FileIncompleteException(String) - Constructor for exception alluxio.exception.FileIncompleteException
Constructs a new exception with the specified detail message.
FileInfo - Class in alluxio.wire
The file information.
FileInfo() - Constructor for class alluxio.wire.FileInfo
Creates a new instance of FileInfo.
FileLocationOptions - Class in alluxio.underfs.options
Method options for file locations in UnderFileSystem.
FileSystemCommand - Class in alluxio.wire
Class to represent a FileSystem command.
FileSystemCommand(CommandType, FileSystemCommandOptions) - Constructor for class alluxio.wire.FileSystemCommand
Create a new instance of FileSystemCommand.
FileSystemCommandOptions - Class in alluxio.wire
Class to represent FileSystemCommand options.
FileSystemCommandOptions() - Constructor for class alluxio.wire.FileSystemCommandOptions
Creates a new instance of FileSystemCommandOptions.
FileTransferType - Enum in alluxio.network.netty
How a read response will transfer block data over the network.
FileUtils - Class in alluxio.util.io
Provides utility methods for working with files and directories.
find(String, AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Finds the first Under File System factory that supports the given path.
find(String, UnderFileSystemConfiguration) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Finds the first Under File System factory that supports the given path.
findAllWithRecorder(String, UnderFileSystemConfiguration, Recorder) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Finds all the Under File System factories that support the given path and record the execution process.
findAllWithRecorder(String, S, Recorder) - Method in class alluxio.extensions.ExtensionFactoryRegistry
Finds all the factories that support the given path and record the detailed execution process.
findClass(String) - Method in class alluxio.extensions.ExtensionsClassLoader
 
findCredentialPropertyKeys(String) - Static method in class alluxio.conf.CredentialPropertyKeys
 
findLowestCommonAncestor(Collection<AlluxioURI>) - Static method in class alluxio.util.io.PathUtils
 
Fingerprint - Class in alluxio.underfs
Fingerprint for a UFS file or directory.
Fingerprint.Tag - Enum in alluxio.underfs
The possible tags within the fingerprint.
Fingerprint.Type - Enum in alluxio.underfs
The possible types of the fingerprint.
fireAndForget(NettyRPCContext, ProtoMessage) - Static method in class alluxio.network.netty.NettyRPC
Sends a request and waits until the request is flushed to network.
FIRST_TIER - Static variable in class alluxio.Constants
 
firstComplete() - Method in class alluxio.concurrent.jsr.CountedCompleter
If this task's pending count is zero, returns this task; otherwise decrements its pending count and returns null.
fixedThreadPool(String, int) - Static method in class alluxio.util.executor.ExecutorServiceFactories
Returns a ExecutorServiceFactory which creates threadpool executors with the given base name and number of threads.
fixedThreadPoolExecutorServiceFactory(String, int) - Static method in class alluxio.util.executor.ExecutorServiceFactories
Returns a ExecutorServiceFactory which creates threadpool executors with the given base name and number of threads.
FJP - alluxio.executor.RpcExecutorType
 
flattenEntries(TwoKeyConcurrentMap.TriFunction<K1, K2, V, R>) - Method in class alluxio.collections.TwoKeyConcurrentMap
Flattens the (key1, key2, value) triples according to the given function.
flowControlWindow(int) - Method in class alluxio.grpc.GrpcServerBuilder
Sets flow control window.
flush() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
FLUSHED_SIGNAL - Static variable in class alluxio.Constants
 
forAddress(GrpcServerAddress, AlluxioConfiguration) - Static method in class alluxio.grpc.GrpcServerBuilder
Create an new instance of GrpcServerBuilder with authentication support.
FORCED - alluxio.master.GraceMode
 
forCreate(long, BlockStoreLocation) - Static method in class alluxio.worker.block.AllocateOptions
Creates default allocation options for block create request.
forEach(BiConsumer<? super PropertyKey, ? super Object>) - Method in class alluxio.conf.AlluxioProperties
Iterates over all the key value pairs and performs the given action.
forEach(Consumer<? super T>) - Method in class alluxio.collections.DelegatingSet
 
fork() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Arranges to asynchronously execute this task in the pool the current task is running in, if applicable, or using the ForkJoinPool.commonPool() if not ForkJoinTask.inForkJoinPool().
ForkJoinPool - Class in alluxio.concurrent.jsr
An ExecutorService for running ForkJoinTasks.
ForkJoinPool() - Constructor for class alluxio.concurrent.jsr.ForkJoinPool
Creates a ForkJoinPool with parallelism equal to Runtime.availableProcessors(), using defaults for all other parameters (see ForkJoinPool(int, ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean, int, int, int, Predicate, long, TimeUnit)).
ForkJoinPool(int) - Constructor for class alluxio.concurrent.jsr.ForkJoinPool
Creates a ForkJoinPool with the indicated parallelism level, using defaults for all other parameters (see ForkJoinPool(int, ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean, int, int, int, Predicate, long, TimeUnit)).
ForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean) - Constructor for class alluxio.concurrent.jsr.ForkJoinPool
ForkJoinPool(int, ForkJoinPool.ForkJoinWorkerThreadFactory, Thread.UncaughtExceptionHandler, boolean, int, int, int, Predicate<? super ForkJoinPool>, long, TimeUnit) - Constructor for class alluxio.concurrent.jsr.ForkJoinPool
Creates a ForkJoinPool with the given parameters.
ForkJoinPool.AlluxioForkJoinWorkerThreadFactory - Class in alluxio.concurrent.jsr
Default ForkJoinWorkerThreadFactory implementation; creates a new ForkJoinWorkerThread using the system class loader as the thread context class loader.
ForkJoinPool.ForkJoinWorkerThreadFactory - Interface in alluxio.concurrent.jsr
Factory for creating new ForkJoinWorkerThreads.
ForkJoinPool.ManagedBlocker - Interface in alluxio.concurrent.jsr
Interface for extending managed parallelism for tasks running in ForkJoinPools.
ForkJoinPoolHelper - Class in alluxio.concurrent
Provides helpers for working with ForkJoinPool.
ForkJoinPoolHelper() - Constructor for class alluxio.concurrent.ForkJoinPoolHelper
 
ForkJoinTask<V> - Class in alluxio.concurrent.jsr
Abstract base class for tasks that run within a ForkJoinPool.
ForkJoinTask() - Constructor for class alluxio.concurrent.jsr.ForkJoinTask
 
ForkJoinWorkerThread - Class in alluxio.concurrent.jsr
A thread managed by a ForkJoinPool, which executes ForkJoinTasks.
ForkJoinWorkerThread(ForkJoinPool) - Constructor for class alluxio.concurrent.jsr.ForkJoinWorkerThread
Creates a ForkJoinWorkerThread operating in the given pool.
format(Object...) - Method in enum alluxio.conf.PropertyKey.Template
Converts a property key template (e.g., PropertyKey.Template.WORKER_TIERED_STORE_LEVEL_ALIAS) to a PropertyKey instance.
formatMode(short, boolean, boolean) - Static method in class alluxio.util.FormatUtils
Formats digital representation of a model as a human-readable string.
formatStackTrace(Thread) - Static method in class alluxio.util.ThreadUtils
 
formatStackTrace(Throwable) - Static method in class alluxio.util.ThreadUtils
Return formatted stacktrace of Throwable instance.
formatTimeTakenMs(long, String) - Static method in class alluxio.util.FormatUtils
Formats time elapsed since the given start time (in milliseconds).
formatTimeTakenNs(long, String) - Static method in class alluxio.util.FormatUtils
Formats time elapsed since the given start time (in nanoseconds).
FormatUtils - Class in alluxio.util
Utility methods to parse specific formats, print according to specific formats or transform among different formats.
formatValue(Object) - Method in class alluxio.conf.PropertyKey
For each property type, there might be different forms of acceptable input format, convert these acceptable formats to proper internal format.
forMove(BlockStoreLocation) - Static method in class alluxio.worker.block.AllocateOptions
Creates default allocation options for moving a block by a client request.
forRequestSpace(long, BlockStoreLocation) - Static method in class alluxio.worker.block.AllocateOptions
Creates default allocation options for requesting more space for a block.
forTierMove(BlockStoreLocation) - Static method in class alluxio.worker.block.AllocateOptions
Creates default allocation options for moving a block during tier-move task.
FREE - alluxio.wire.CommandType
Ask worker to free files.
FREE_BYTES - alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 
freeWorker() - Method in interface alluxio.worker.block.BlockWorker
Frees all blocks in the current worker by deleting all block store directories.
from(AlluxioStatusException) - Static method in exception alluxio.exception.runtime.AlluxioRuntimeException
Converts an arbitrary AlluxioStatusException to an Alluxio runtime exception.
from(JobDescription) - Static method in class alluxio.job.JobDescription
create a job description from JobDescription proto.
from(ReadRequest) - Static method in class alluxio.wire.BlockReadRequest
Creates an instance of BlockReadRequest.
from(Status) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts an Alluxio exception from status and message representation to native representation.
from(IOException) - Static method in exception alluxio.exception.runtime.AlluxioRuntimeException
Converts an IOException to a corresponding runtime exception.
from(RuntimeException) - Static method in exception alluxio.exception.runtime.AlluxioRuntimeException
Converts an arbitrary RuntimeException to an Alluxio runtime exception.
from(String, double, MetricType) - Static method in class alluxio.metrics.Metric
Creates the metric from the full name and the value.
from(Throwable) - Static method in exception alluxio.exception.runtime.AlluxioRuntimeException
Converts an arbitrary throwable to an Alluxio runtime exception.
fromAlluxioException(AlluxioException) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts checked Alluxio exceptions to Alluxio status exceptions.
fromCheckedException(Throwable) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts checked throwables to Alluxio status exceptions.
fromCliString(String) - Static method in class alluxio.security.authorization.AclEntry
Creates an AclEntry from a string.
fromCliStringWithoutPermissions(String) - Static method in class alluxio.security.authorization.AclEntry
Creates an AclEntry from a string without permissions.
fromFsProto(FsOpPId) - Static method in class alluxio.wire.OperationId
Creates FsOpId from proto.
fromIOException(IOException) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts an IOException to a corresponding status exception.
fromJournalProto(Journal.JournalOpPId) - Static method in class alluxio.wire.OperationId
Creates FsOpId from proto.
fromJson(String) - Static method in interface alluxio.util.JsonSerializable
 
fromJson(String, T[]) - Static method in interface alluxio.util.JsonSerializable
 
fromMountEntry(File.AddMountPointEntry) - Static method in class alluxio.grpc.GrpcUtils
Creates mount proto options from File.AddMountPointEntry.
fromProto(BackupPStatus) - Static method in class alluxio.wire.BackupStatus
 
fromProto(Bits) - Static method in enum alluxio.security.authorization.Mode.Bits
 
fromProto(BlockInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(BlockLocation) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(BlockMasterInfo) - Static method in class alluxio.wire.BlockMasterInfo
Creates a new instance of BlockMasterInfo from a proto representation.
fromProto(BlockMasterInfoField) - Static method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 
fromProto(ConfigCheckReport) - Static method in class alluxio.wire.ConfigCheckReport
Creates a new instance of ConfigCheckReport from proto representation.
fromProto(ConfigProperty) - Static method in class alluxio.wire.Property
 
fromProto(FileBlockInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(FileInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(GetConfigHashPResponse) - Static method in class alluxio.wire.ConfigHash
 
fromProto(GetConfigurationPResponse) - Static method in class alluxio.wire.Configuration
 
fromProto(InconsistentProperty) - Static method in class alluxio.wire.InconsistentProperty
Creates a new instance of InconsistentProperty from proto representation.
fromProto(ListStatusPartialPResponse) - Static method in class alluxio.client.file.ListStatusPartialResult
Generate a ListStatusPartialResult from a ListStatusPartialPResponse.
fromProto(LoadDescendantPType) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(LocalityTier) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(Metric) - Static method in class alluxio.metrics.Metric
Constructs the metric object from the proto format.
fromProto(MountPointInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(NetAddress) - Static method in class alluxio.wire.Address
Creates a new instance of Address from proto representation.
fromProto(PAcl) - Static method in class alluxio.grpc.GrpcUtils
 
fromProto(PAclAction) - Static method in class alluxio.grpc.GrpcUtils
 
fromProto(PAclEntry) - Static method in class alluxio.grpc.GrpcUtils
 
fromProto(PAclEntryType) - Static method in class alluxio.grpc.GrpcUtils
 
fromProto(PMode) - Static method in class alluxio.security.authorization.Mode
Creates Mode from proto PMode.
fromProto(ReadPType) - Static method in enum alluxio.client.ReadType
 
fromProto(SyncPointInfo) - Static method in class alluxio.wire.SyncPointInfo
Generate sync point information from the proto representation.
fromProto(TieredIdentity) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(WorkerInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(WorkerNetAddress) - Static method in class alluxio.grpc.GrpcUtils
Converts a proto type to a wire type.
fromProto(WritePType) - Static method in enum alluxio.client.WriteType
 
fromProto(File.PSetAclAction) - Static method in class alluxio.util.proto.ProtoUtils
Converts proto type to wire type.
fromProto(Acl.AccessControlList) - Static method in class alluxio.util.proto.ProtoUtils
 
fromProto(Acl.AclAction) - Static method in class alluxio.util.proto.ProtoUtils
 
fromProto(Acl.AclActions) - Static method in class alluxio.util.proto.ProtoUtils
 
fromProto(Acl.AclEntry) - Static method in class alluxio.util.proto.ProtoUtils
 
fromProto(Acl.AclEntryType) - Static method in class alluxio.util.proto.ProtoUtils
 
fromProto(Status.PStatus) - Static method in class alluxio.network.protocol.RPCProtoMessage
Creates a Status from a protocol buffer type status.
fromProto(Status.PStatus) - Static method in class alluxio.util.proto.ProtoUtils
Creates a Status from a protocol buffer type status.
fromShort(short) - Static method in enum alluxio.security.authorization.Mode.Bits
Creates a Mode.Bits from a short.
fromShort(short) - Method in class alluxio.security.authorization.Mode
Sets Mode bits using a digital representation.
fromStatusRuntimeException(StatusRuntimeException) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts a gRPC StatusRuntimeException to an Alluxio status exception.
fromString(String) - Static method in enum alluxio.client.ReadType
Creates an instance type from the string.
fromString(String) - Static method in class alluxio.conf.PropertyKey
Parses a string and return its corresponding PropertyKey, throwing exception if no such a property can be found.
fromString(String) - Static method in class alluxio.metrics.MetricKey
Parses a given name and return its corresponding MetricKey, throwing exception if no such a Metric can be found.
fromString(String) - Static method in enum alluxio.metrics.MetricsSystem.InstanceType
Creates an instance type from the string.
fromString(String) - Static method in enum alluxio.security.authorization.Mode.Bits
 
fromString(String) - Static method in interface alluxio.uri.Authority
Gets the Authority object from the input string.
fromString(String, AlluxioConfiguration) - Static method in class alluxio.network.TieredIdentityFactory
 
fromStringEntries(String, String, List<String>) - Static method in class alluxio.security.authorization.AccessControlList
Converts a list of string entries into an AccessControlList or a DefaultAccessControlList.
fromThrowable(Throwable) - Static method in exception alluxio.exception.status.AlluxioStatusException
Converts an arbitrary throwable to an Alluxio status exception.
fromThrowable(Throwable) - Static method in class alluxio.grpc.GrpcExceptionUtils
Converts a throwable to a gRPC exception.
FUSE - alluxio.metrics.MetricsSystem.InstanceType
 
FUSE_AUTH_POLICY_CLASS - Static variable in class alluxio.conf.PropertyKey
 
FUSE_AUTH_POLICY_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_AUTH_POLICY_CUSTOM_GROUP - Static variable in class alluxio.conf.PropertyKey
 
FUSE_AUTH_POLICY_CUSTOM_GROUP - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_AUTH_POLICY_CUSTOM_USER - Static variable in class alluxio.conf.PropertyKey
 
FUSE_AUTH_POLICY_CUSTOM_USER - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_CACHED_PATH_COUNT - Static variable in class alluxio.metrics.MetricKey
 
FUSE_CACHED_PATHS_MAX - Static variable in class alluxio.conf.PropertyKey
 
FUSE_CACHED_PATHS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_DEBUG_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_DEBUG_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_FS_NAME - Static variable in class alluxio.conf.PropertyKey
 
FUSE_FS_NAME - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_JNIFUSE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_JNIFUSE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_JNIFUSE_LIBFUSE_VERSION - Static variable in class alluxio.conf.PropertyKey
 
FUSE_JNIFUSE_LIBFUSE_VERSION - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
FUSE_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_MOUNT_ALLUXIO_PATH - Static variable in class alluxio.conf.PropertyKey
 
FUSE_MOUNT_ALLUXIO_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_MOUNT_OPTIONS - Static variable in class alluxio.conf.PropertyKey
 
FUSE_MOUNT_OPTIONS - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_MOUNT_POINT - Static variable in class alluxio.conf.PropertyKey
 
FUSE_MOUNT_POINT - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_POSITION_READ_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_POSITION_READ_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_READ_WRITE_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
FUSE_SHARED_CACHING_READER_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_SHARED_CACHING_READER_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_SPECIAL_COMMAND_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_SPECIAL_COMMAND_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_STAT_CACHE_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
FUSE_STAT_CACHE_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_TOTAL_CALLS - Static variable in class alluxio.metrics.MetricKey
 
FUSE_UMOUNT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
FUSE_UMOUNT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_UPDATE_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
FUSE_USER_GROUP_TRANSLATION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_USER_GROUP_TRANSLATION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_WEB - alluxio.util.network.NetworkAddressUtils.ServiceType
FUSE web service (Jetty).
FUSE_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
FUSE_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_WEB_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
FUSE_WEB_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
FUSE_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
FUSE_WEB_PORT - Static variable in class alluxio.conf.PropertyKey
 
FUSE_WEB_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 

G

GarbageCollectorMXBeanView(GarbageCollectorMXBean) - Constructor for class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
GB - Static variable in class alluxio.Constants
 
GCS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
 
GCS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
GCS_CREDENTIAL_PATH - Static variable in class alluxio.conf.PropertyKey
 
GCS_CREDENTIAL_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
GCS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
 
GCS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
generateChildDirACL(Short) - Method in class alluxio.security.authorization.DefaultAccessControlList
Creates a child directory's access ACL and default ACL based on the default ACL.
generateChildFileACL(Short) - Method in class alluxio.security.authorization.DefaultAccessControlList
create a child file 's accessACL based on the default ACL.
generateOrderedNodeInfos(Collection<WorkerInfo>) - Static method in class alluxio.util.webui.WebUtils
Order the nodes by hostName and generate NodeInfo list for UI display.
generateQueryString(Map<String, String>) - Static method in class alluxio.util.URIUtils
Generates a query string from a Map of key/value pairs.
generateThreadName(String, String) - Static method in class alluxio.heartbeat.HeartbeatThread
 
get() - Method in class alluxio.CloseableSupplier
 
get() - Method in class alluxio.concurrent.jsr.CompletableFuture
Waits if necessary for this future to complete, and then returns its result.
get() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Waits if necessary for the computation to complete, and then retrieves its result.
get() - Method in class alluxio.conf.Hash
If Hash.markOutdated() is called since last Hash.get(), then the version will be recomputed, otherwise, the internally cached version is returned.
get() - Method in class alluxio.DefaultSupplier
 
get() - Method in class alluxio.resource.CloseableResource
 
get(int) - Method in interface alluxio.collections.BitSet
 
get(int) - Method in class alluxio.collections.BuiltinBitSet
 
get(int) - Method in class alluxio.collections.UnmodifiableArrayList
 
get(long) - Method in interface alluxio.underfs.UfsManager
Gets UFS information from the manager if this mount ID exists, or throws exception otherwise.
get(long, TimeUnit) - Method in class alluxio.concurrent.jsr.CompletableFuture
Waits if necessary for at most the given time for this future to complete, and then returns its result, if available.
get(long, TimeUnit) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Waits if necessary for at most the given time for the computation to complete, and then retrieves its result, if available.
get(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Gets the User from the ThreadLocal variable.
get(AlluxioConfiguration) - Static method in class alluxio.security.group.GroupMappingService.Factory
Gets the cached groups mapping service being used to map user-to-groups.
get(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the value for the given key in the Properties; if this key is not found, a RuntimeException is thrown.
get(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
 
get(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the value for the given key in the Properties; if this key is not found, a RuntimeException is thrown.
get(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
get(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
get(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
get(PropertyKey, ConfigurationValueOptions) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the value for the given key in the Properties; if this key is not found, a RuntimeException is thrown.
get(PropertyKey, ConfigurationValueOptions) - Static method in class alluxio.conf.Configuration
Gets the value for the given key in the Properties; if this key is not found, a RuntimeException is thrown.
get(PropertyKey, ConfigurationValueOptions) - Method in class alluxio.conf.InstancedConfiguration
 
get(PropertyKey, ConfigurationValueOptions) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
get(PropertyKey, ConfigurationValueOptions) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
get(Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
get(String, Integer) - Static method in class alluxio.util.network.HttpUtils
Uses the get method to send a url with arguments by http, this method can call RESTful Api.
get(String, Integer, HttpUtils.IProcessInputStream) - Static method in class alluxio.util.network.HttpUtils
Uses the get method to send a url with arguments by http, this method can call RESTful Api.
get(K, LockMode) - Method in class alluxio.collections.LockPool
Locks the specified key in the specified mode.
get(K, LockMode, boolean) - Method in class alluxio.collections.LockPool
Locks the specified key in the specified mode.
GET_BLOCK_SIZE_BYTE - alluxio.metrics.MetricInfo.UfsOps
 
GET_DIRECTORY_STATUS_ - alluxio.metrics.MetricInfo.UfsOps
 
GET_FILE_LOCATIONS - alluxio.metrics.MetricInfo.UfsOps
 
GET_FILE_STATUS - alluxio.metrics.MetricInfo.UfsOps
 
GET_FINGERPRINT - alluxio.metrics.MetricInfo.UfsOps
 
GET_SPACE - alluxio.metrics.MetricInfo.UfsOps
 
GET_STATUS - alluxio.metrics.MetricInfo.UfsOps
 
getAbsolutePath() - Method in class alluxio.util.webui.UIFileInfo
Gets absolute path.
getAccessControlException() - Method in class alluxio.wire.MasterWebUIBrowse
Gets access control exception.
getAcl() - Method in class alluxio.client.file.URIStatus
 
getAcl() - Method in class alluxio.underfs.options.CreateOptions
 
getAcl() - Method in class alluxio.wire.FileInfo
 
getAclPair(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getAclPair(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
getAclPair(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the ACL and the Default ACL of a file or directory in under file system.
getAclPair(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getActions() - Method in class alluxio.security.authorization.AclActions
 
getActions() - Method in class alluxio.security.authorization.AclEntry
 
getActiveSyncInfo() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getActiveSyncInfo() - Method in class alluxio.underfs.BaseUnderFileSystem
 
getActiveSyncInfo() - Method in interface alluxio.underfs.UnderFileSystem
Return the active sync info for the specified syncPoints.
getActiveSyncInfo() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getActiveThreadCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the number of threads that are currently stealing or executing tasks.
getAddedBlocks() - Method in class alluxio.worker.block.BlockHeartbeatReport
Gets the list of blocks added by the worker in the heartbeat this report represents.
getAddress() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
getAddress() - Method in class alluxio.util.webui.UIMasterInfo
Gets master address.
getAddress() - Method in class alluxio.wire.MasterInfo
 
getAddress() - Method in class alluxio.wire.WorkerInfo
 
getAddresses() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
getAdvice() - Method in class alluxio.cli.ValidationTaskResult
 
getAlias(int) - Method in interface alluxio.StorageTierAssoc
 
getAliases() - Method in class alluxio.conf.PropertyKey
 
getAllInTopologicalOrder() - Method in class alluxio.collections.DirectedAcyclicGraph
Gets all payloads of the DAG in the topological order.
getAlluxioPath() - Method in class alluxio.worker.block.CreateBlockOptions
 
getAlluxioStorageType() - Method in enum alluxio.client.ReadType
 
getAlluxioStorageType() - Method in enum alluxio.client.WriteType
 
getAnnotation(PropertyKey) - Method in class alluxio.conf.DeprecatedKeyChecker
Returns the annotation attached to the given property key.
getAppConfigurationEntry(String) - Method in class alluxio.security.login.LoginModuleConfiguration
 
getArrayHeaderSize() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
Returns the fixed overhead of an array of any type or length in this JVM.
getAsyncMode() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if this pool uses local first-in-first-out scheduling mode for forked tasks that are never joined.
getAttemptCount() - Method in class alluxio.retry.CountingRetry
 
getAttemptCount() - Method in interface alluxio.retry.RetryPolicy
How many retries have been performed.
getAttemptCount() - Method in class alluxio.retry.SleepingRetry
 
getAttemptCount() - Method in class alluxio.retry.TimeBoundedRetry
 
getAttemptCount() - Method in class alluxio.retry.TimeoutRetry
 
getAuthenticatedUserInfo() - Method in class alluxio.security.authentication.plain.SaslServerHandlerPlain
 
getAuthenticatedUserInfo() - Method in interface alluxio.security.authentication.SaslServerHandler
Used to get the authenticated user info after the completed session.
getAuthenticationServer() - Method in class alluxio.grpc.GrpcServer
 
getAuthMethod() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
 
getAuthMethod(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Gets the connection authentication method from the ThreadLocal variable.
getAuthority() - Method in class alluxio.AlluxioURI
 
getAuthority() - Method in class alluxio.uri.StandardURI
 
getAuthority() - Method in interface alluxio.uri.URI
 
getAuthorizationID() - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
getAuthorizedUserName() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
 
getAvailable() - Method in class alluxio.extensions.ExtensionFactoryRegistry
Returns a read-only view of the available base factories.
getAvailableBytes() - Method in class alluxio.wire.JournalDiskInfo
 
getAvailableBytes() - Method in interface alluxio.worker.block.meta.StorageDir
Gets the total available capacity of this StorageDir in bytes.
getAvailableBytes() - Method in interface alluxio.worker.block.meta.StorageTier
 
getBackupId() - Method in class alluxio.wire.BackupStatus
 
getBackupUri() - Method in class alluxio.wire.BackupStatus
 
getBaseName(String) - Static method in class alluxio.metrics.Metric
Gets the simple name without the tags.
getBatchSize() - Method in class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer
 
getBatchSize() - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Gets the batch size.
getBatchSize() - Method in class alluxio.underfs.ObjectUnderFileSystem.RenameBuffer
 
getBindAddress(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Helper method to get the bind hostname for a given service.
getBindHost(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Helper method to get the InetSocketAddress bind address on a given service.
getBindHostKey() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
Gets the key of bind hostname.
getBindHostKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the key of bind hostname.
getBindPort() - Method in class alluxio.grpc.GrpcServer
 
getBlockCount() - Method in class alluxio.util.webui.NodeInfo
Gets worker block count.
getBlockCount() - Method in class alluxio.wire.WorkerInfo
 
getBlockCount() - Method in class alluxio.wire.WorkerWebUIOverview
Gets block count.
getBlockId() - Method in class alluxio.wire.BlockInfo
 
getBlockId() - Method in interface alluxio.worker.block.meta.BlockMeta
 
getBlockId() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getBlockIds() - Method in class alluxio.client.file.URIStatus
 
getBlockIds() - Method in class alluxio.util.webui.UIFileInfo
Gets BlockId List.
getBlockIds() - Method in class alluxio.wire.FileInfo
 
getBlockIds() - Method in class alluxio.wire.PersistFile
 
getBlockIds() - Method in interface alluxio.worker.block.meta.StorageDir
Returns the list of block ids in this dir.
getBlockInfo() - Method in class alluxio.wire.BlockLocationInfo
 
getBlockInfo() - Method in class alluxio.wire.FileBlockInfo
 
getBlockInfo(long) - Method in class alluxio.client.file.URIStatus
 
getBlockLength() - Method in class alluxio.util.webui.UIFileBlockInfo
Gets block length.
getBlockList() - Method in interface alluxio.worker.block.BlockStoreMeta
Note: This method is only available when users initialize the blockStoreMeta with full block meta requirement.
getBlockListByStorageLocation() - Method in interface alluxio.worker.block.BlockStoreMeta
Note: This method is only available when users initialize the blockStoreMeta with full block meta requirement.
getBlockLocation() - Method in interface alluxio.worker.block.meta.BlockMeta
 
getBlockLocation() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
Gets the BlockMeta from this storage dir by its block id.
getBlockMeta(long, long, long) - Method in interface alluxio.worker.block.BlockStore
Gets the metadata of a specific block from local storage.
getBlocks() - Method in interface alluxio.worker.block.meta.StorageDir
Returns the list of blocks stored in this dir.
getBlockSize() - Method in class alluxio.underfs.UfsFileStatus
 
getBlockSize() - Method in interface alluxio.worker.block.meta.BlockMeta
 
getBlockSize() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getBlockSizeByte(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getBlockSizeByte(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Gets the block size in bytes.
getBlockSizeByte(String) - Method in interface alluxio.underfs.UnderFileSystem
Deprecated.
getBlockSizeByte(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getBlockSizeBytes() - Method in class alluxio.client.file.URIStatus
 
getBlockSizeBytes() - Method in class alluxio.util.webui.UIFileInfo
Gets block size bytes.
getBlockSizeBytes() - Method in class alluxio.wire.FileInfo
 
getBlockSizeBytes() - Method in class alluxio.wire.MasterWebUIBrowse
Gets block size bytes.
getBlockSizeBytes() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets block size bytes.
getBlocksOnTier() - Method in class alluxio.util.webui.UIFileInfo
Gets blocks on tier.
getBlockStore() - Method in interface alluxio.worker.block.BlockWorker
 
getBlockStoreMeta() - Method in interface alluxio.worker.block.BlockStore
Gets the metadata of the entire store in a snapshot.
getBlockStoreMetaFull() - Method in interface alluxio.worker.block.BlockStore
Similar as BlockStore.getBlockStoreMeta() except that this includes more information about the block store (e.g.
getBlockWriter(long, long) - Method in interface alluxio.worker.block.BlockStore
Creates a writer to write data to a temp block.
getBoolean(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the boolean representation of the value for the given key.
getBoolean(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the boolean representation of the value for the given key.
getBoolean(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getBoolean(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getBoolean(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getBucketName(AlluxioURI) - Static method in class alluxio.util.UnderFileSystemUtils
 
getBuffer() - Method in class alluxio.grpc.DataMessage
 
getBufferFromStream(InputStream) - Static method in class alluxio.grpc.GrpcSerializationUtils
Gets a buffer directly from a gRPC input stream.
getByField(IndexDefinition<T, V>, V) - Method in class alluxio.collections.IndexedSet
Gets a subset of objects with the specified field value.
getByField(V) - Method in interface alluxio.collections.FieldIndex
Gets a subset of objects with the specified field value.
getByField(V) - Method in class alluxio.collections.NonUniqueFieldIndex
 
getByField(V) - Method in class alluxio.collections.UniqueFieldIndex
 
getByteBufFromReadableBuffer(ReadableBuffer) - Static method in class alluxio.grpc.GrpcSerializationUtils
Gets a Netty buffer directly from a gRPC ReadableBuffer.
getBytes(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the bytes of the value for the given key.
getBytes(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the bytes of the value for the given key.
getBytes(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getBytes(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getBytes(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getCacheContext() - Method in class alluxio.client.file.URIStatus
 
getCacheHitLocal() - Method in class alluxio.wire.MasterWebUIMetrics
Gets cache hit local.
getCacheHitRemote() - Method in class alluxio.wire.MasterWebUIMetrics
Gets cache hit remote.
getCacheIdentifier() - Method in class alluxio.client.file.CacheContext
Returns an string as a hint from computation to indicate the file.
getCacheMiss() - Method in class alluxio.wire.MasterWebUIMetrics
Gets cache miss.
getCacheQuota() - Method in class alluxio.client.file.CacheContext
 
getCacheScope() - Method in class alluxio.client.file.CacheContext
 
getCapacity() - Method in class alluxio.util.webui.NodeInfo
Gets capacity.
getCapacity() - Method in class alluxio.util.webui.StorageTierInfo
Gets capacity.
getCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
 
getCapacity() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets capacity.
getCapacityBytes() - Method in class alluxio.util.webui.UIStorageDir
Gets capacity bytes.
getCapacityBytes() - Method in class alluxio.util.webui.UIUsageOnTier
Gets capacity bytes.
getCapacityBytes() - Method in class alluxio.wire.BlockMasterInfo
 
getCapacityBytes() - Method in class alluxio.wire.WorkerInfo
 
getCapacityBytes() - Method in class alluxio.wire.WorkerWebUIOverview
Gets capacity bytes.
getCapacityBytes() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getCapacityBytes() - Method in interface alluxio.worker.block.meta.StorageDir
Gets the total capacity of this StorageDir in bytes, which is a constant once this StorageDir has been initialized.
getCapacityBytes() - Method in interface alluxio.worker.block.meta.StorageTier
 
getCapacityBytesOnDirs() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getCapacityBytesOnTiers() - Method in class alluxio.wire.BlockMasterInfo
 
getCapacityBytesOnTiers() - Method in class alluxio.wire.WorkerInfo
 
getCapacityBytesOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getChangedFiles(AlluxioURI) - Method in class alluxio.SyncInfo
REturns a set of changed files.
getChannel() - Method in class alluxio.grpc.GrpcChannel
 
getChannel() - Method in class alluxio.network.netty.NettyRPCContext
 
getChannel() - Method in class alluxio.worker.block.io.BlockReader
Returns a readable byte channel of the block.
getChannel() - Method in class alluxio.worker.block.io.BlockWriter
 
getChannel() - Method in class alluxio.worker.block.io.DelegatingBlockReader
 
getChannel() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
getChannel() - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
getChannelClass(boolean, PropertyKey, AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
Get the proper channel class.
getChannelId() - Method in class alluxio.grpc.GrpcChannelKey
 
getChannelKey() - Method in class alluxio.grpc.GrpcChannel
 
getChannelType(PropertyKey, AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
Get the proper channel type.
getChildName(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Gets the child name based on the parent name.
getChildren() - Method in class alluxio.collections.DirectedAcyclicGraphNode
Gets the children nodes of the node.
getChildren(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Gets the payloads for the children of the given node.
getChunkSize() - Method in class alluxio.wire.BlockReadRequest
 
getClass(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the value for the given key as a class.
getClass(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the value for the given key as a class.
getClass(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getClass(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getClass(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getClassName() - Method in interface alluxio.util.JsonSerializable
 
getCleanedPathComponents(String) - Static method in class alluxio.util.io.PathUtils
Get the components of a path that has already been cleaned.
getClient(String, String, String, int, boolean) - Static method in class alluxio.master.ZkMasterInquireClient
Gets the client.
getClientChannelClass(boolean) - Static method in class alluxio.util.network.NettyUtils
Returns the correct SocketChannel class based on ChannelType.
getClientHostName(AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets the local hostname to be used by the client.
getClientSslContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
 
getClientSslContext() - Method in interface alluxio.util.network.tls.SslContextProvider
 
getClientUser(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Gets the user name from the ThreadLocal variable.
getClock() - Method in class alluxio.time.TimeContext
 
getCloser() - Method in class alluxio.grpc.GrpcService
Gets the closer associated with this service.
getClusterConf() - Method in class alluxio.ClientContext
 
getClusterConf() - Method in class alluxio.wire.Configuration
 
getClusterConf(GetConfigurationPResponse, AlluxioConfiguration, Scope) - Static method in class alluxio.conf.Configuration
Loads the cluster level configuration from the get configuration response, filters out the configuration for certain scope, and merges it with the existing configuration.
getClusterConfHash() - Method in class alluxio.ClientContext
 
getClusterConfHash() - Method in class alluxio.wire.Configuration
 
getClusterConfigHash() - Method in class alluxio.wire.ConfigHash
 
getClusterId() - Method in class alluxio.wire.MasterWebUIOverview
Gets cluster id.
getCmd() - Method in class alluxio.shell.CommandReturn
Gets the command run.
getCollectionCount() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
 
getCollectionTime() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
 
getCommand() - Method in class alluxio.shell.ShellCommand
Gets the command.
getCommandName() - Method in interface alluxio.cli.Command
Gets the command name as input from the shell.
getCommandOptions() - Method in class alluxio.wire.FileSystemCommand
 
getCommands() - Method in class alluxio.cli.AbstractShell
 
getCommandType() - Method in class alluxio.wire.FileSystemCommand
 
getCommitPath() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getCommittedBytes() - Method in interface alluxio.worker.block.meta.StorageDir
Gets the total size of committed blocks in this StorageDir in bytes.
getCommonPoolParallelism() - Static method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the targeted parallelism level of the common pool.
getCommonPrefixes() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Use common prefixes to infer pseudo-directories in object store.
getCommonRoots() - Method in class alluxio.conf.path.TrieNode
 
getCompleter() - Method in class alluxio.concurrent.jsr.CountedCompleter
Returns the completer established in this task's constructor, or null if none.
getConfAddress() - Method in class alluxio.AbstractClient
By default, return the same underlying address as AbstractClient.getRemoteSockAddress().
getConfAddress() - Method in class alluxio.AbstractJobMasterClient
 
getConfAddress() - Method in class alluxio.AbstractMasterClient
 
getConfAddress() - Method in interface alluxio.Client
 
getConfigCheckErrorNum() - Method in class alluxio.wire.MasterWebUIOverview
Gets config check error num.
getConfigCheckErrors() - Method in class alluxio.wire.MasterWebUIOverview
Gets config check errors.
getConfigCheckStatus() - Method in class alluxio.wire.MasterWebUIOverview
Gets config check status.
getConfigCheckWarnNum() - Method in class alluxio.wire.MasterWebUIOverview
Gets config check warn num.
getConfigCheckWarns() - Method in class alluxio.wire.MasterWebUIOverview
Gets config check warns.
getConfigErrors() - Method in class alluxio.wire.ConfigCheckReport
 
getConfigStatus() - Method in class alluxio.wire.ConfigCheckReport
 
getConfiguration() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getConfiguration() - Method in class alluxio.underfs.BaseUnderFileSystem
 
getConfiguration() - Method in interface alluxio.underfs.UnderFileSystem
Gets the under file system configuration.
getConfiguration() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getConfiguration() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
getConfiguration() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
getConfiguration() - Method in class alluxio.wire.AlluxioMasterInfo
 
getConfiguration() - Method in class alluxio.wire.AlluxioProxyInfo
 
getConfiguration() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getConfiguration() - Method in class alluxio.wire.MasterWebUIConfiguration
Gets configuration.
getConfiguration() - Method in class alluxio.wire.WorkerWebUIConfiguration
Gets configuration.
getConfiguration(AlluxioURI, PropertyKey) - Method in interface alluxio.conf.path.PathConfiguration
 
getConfiguration(AlluxioURI, PropertyKey) - Method in class alluxio.conf.path.PrefixPathConfiguration
 
getConfiguration(GetConfigurationPOptions) - Method in interface alluxio.worker.block.BlockWorker
 
getConfiguration(Scope) - Static method in class alluxio.conf.Configuration
Gets all configuration properties filtered by the specified scope.
getConfigWarns() - Method in class alluxio.wire.ConfigCheckReport
 
getConfMasterInquireClient() - Method in class alluxio.master.MasterClientContext
 
getConnectAddress(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Helper method to get the InetSocketAddress address for client to communicate with the service.
getConnectDetails() - Method in interface alluxio.master.MasterInquireClient
Returns canonical connect details representing how this client connects to the master.
getConnectDetails() - Method in class alluxio.master.PollingMasterInquireClient
 
getConnectDetails() - Method in class alluxio.master.SingleMasterInquireClient
 
getConnectDetails() - Method in class alluxio.master.ZkMasterInquireClient
 
getConnectDetails(AlluxioConfiguration) - Static method in class alluxio.master.MasterInquireClient.Factory
 
getConnectHost(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Provides an externally resolvable hostname for client to communicate with the service.
getConnectionUser(AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Gets the connection user name from the ThreadLocal variable.
getConnectionUserName() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
 
getConsistencyLevel() - Method in class alluxio.conf.PropertyKey
 
getContainerHost() - Method in class alluxio.wire.WorkerNetAddress
 
getContainerId(long) - Static method in class alluxio.master.block.BlockId
 
getContentHash() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
 
getContentHash() - Method in class alluxio.underfs.UfsFileStatus
 
getContentLength() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
Gets the size of object contents in bytes.
getContentLength() - Method in class alluxio.underfs.UfsFileStatus
Get the content size in bytes.
getCounters() - Method in class alluxio.util.BucketCounter
 
getCreateParent() - Method in class alluxio.underfs.options.CreateOptions
 
getCreateParent() - Method in class alluxio.underfs.options.MkdirsOptions
 
getCreationTime() - Method in class alluxio.util.webui.UIFileInfo
Gets creation time.
getCreationTimeMs() - Method in class alluxio.client.file.URIStatus
 
getCreationTimeMs() - Method in class alluxio.wire.FileInfo
 
getCredentials() - Static method in class alluxio.conf.CredentialPropertyKeys
return CREDENTIAL set.
getCurrentDirectory() - Method in class alluxio.wire.MasterWebUIBrowse
Gets current directory.
getCurrentMs() - Static method in class alluxio.util.CommonUtils
 
getCurrentPath() - Method in class alluxio.wire.MasterWebUIBrowse
Gets current path.
getCurrentPath() - Method in class alluxio.wire.MasterWebUILogs
Gets current path.
getCurrentPath() - Method in class alluxio.wire.WorkerWebUILogs
Gets current path.
getCurrentThreadIdentifier() - Static method in class alluxio.util.ThreadUtils
 
getCustomProvider() - Method in class alluxio.security.authentication.plain.CustomAuthenticationProvider
 
getDatabase() - Method in class alluxio.client.hive.HiveCacheContext
 
getDataPoints() - Method in class alluxio.metrics.TimeSeries
 
getDataPort() - Method in class alluxio.wire.WorkerNetAddress
 
getDataPortSocketAddress(WorkerNetAddress, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Extracts dataPort socket address from Alluxio representation of network address.
getDebug() - Method in class alluxio.wire.MasterWebUIBrowse
Gets debug.
getDebug() - Method in class alluxio.wire.MasterWebUIInit
Gets debug.
getDebug() - Method in class alluxio.wire.MasterWebUILogs
Gets debug.
getDebug() - Method in class alluxio.wire.MasterWebUIMasters
Gets debug.
getDebug() - Method in class alluxio.wire.MasterWebUIMountTable
Gets debug.
getDebug() - Method in class alluxio.wire.MasterWebUIOverview
Gets debug.
getDebug() - Method in class alluxio.wire.MasterWebUIWorkers
Gets debug.
getDebug() - Method in class alluxio.wire.WorkerWebUIInit
Gets debug.
getDebug() - Method in class alluxio.wire.WorkerWebUILogs
Gets debug.
getDefaultAcl() - Method in class alluxio.client.file.URIStatus
 
getDefaultAcl() - Method in class alluxio.wire.FileInfo
 
getDefaultPort() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
Gets the default port number on service.
getDefaultPort() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the default port number on service.
getDefaultSupplier() - Method in class alluxio.conf.PropertyKey
 
getDefaultValue() - Method in class alluxio.conf.PropertyKey
 
getDelay() - Method in class alluxio.util.executor.ControllableQueue.DelayNode
 
getDelegate() - Method in class alluxio.worker.block.io.DelegatingBlockReader
 
getDelimiter() - Method in class alluxio.conf.PropertyKey
 
getDependencies() - Method in interface alluxio.Server
 
getDeprecationMessage(PropertyKey) - Static method in class alluxio.conf.PropertyKey
 
getDepth() - Method in class alluxio.AlluxioURI
Returns the number of elements of the path component of the AlluxioURI.
getDesc() - Method in class alluxio.cli.ValidationTaskResult
 
getDescription() - Method in interface alluxio.cli.Command
 
getDescription() - Method in class alluxio.conf.PropertyKey
 
getDescription() - Method in class alluxio.DefaultSupplier
 
getDescription() - Method in class alluxio.metrics.MetricKey
 
getDeviceSpec() - Method in class alluxio.util.UnixMountInfo
 
getDir(int) - Method in interface alluxio.worker.block.meta.StorageTier
Returns a directory for the given index.
getDirectMemUsed() - Static method in class alluxio.metrics.MetricsSystem
 
getDirectoryPathsOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getDirectoryStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getDirectoryStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getDirectoryStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the directory status.
getDirectoryStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getDirIndex() - Method in interface alluxio.worker.block.meta.StorageDir
Returns the zero-based index of this dir in its parent StorageTier.
getDirMedium() - Method in interface alluxio.worker.block.meta.StorageDir
 
getDirPath() - Method in class alluxio.util.webui.UIStorageDir
Gets dir path.
getDirPath() - Method in interface alluxio.worker.block.meta.StorageDir
 
getDiskCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets disk capacity.
getDiskFreeCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets disk free capacity.
getDiskPath() - Method in class alluxio.wire.JournalDiskInfo
 
getDiskPathWithSchema() - Method in class alluxio.wire.JournalDiskInfo
 
getDiskUsedCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets disk used capacity.
getDisplayType() - Method in class alluxio.conf.PropertyKey
 
getDomainSocketPath() - Method in class alluxio.wire.WorkerNetAddress
 
getDouble(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the double representation of the value for the given key.
getDouble(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the double representation of the value for the given key.
getDouble(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getDouble(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getDouble(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getDst() - Method in class alluxio.job.CopyJobRequest
 
getDuration(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the time of the key as a duration.
getDuration(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the time of the key as a duration.
getDuration(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getDuration(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getDuration(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getEC2ProductCode() - Static method in class alluxio.util.EnvironmentUtils
Gets the EC2 product code if any.
getEmbeddedJournalAddresses(AlluxioConfiguration, NetworkAddressUtils.ServiceType) - Static method in class alluxio.util.ConfigurationUtils
Gets the embedded journal addresses to use for the given service type (either master-raft or job-master-raft).
getEncodedLength() - Method in interface alluxio.network.protocol.EncodedMessage
Returns the number bytes for the message when it is encoded.
getEncodedLength() - Method in enum alluxio.network.protocol.RPCMessage.Type
 
getEncodedLength() - Method in class alluxio.network.protocol.RPCProtoMessage
 
getEnd() - Method in class alluxio.wire.BlockReadRequest
 
getEntries() - Method in class alluxio.security.authorization.AccessControlList
Returns a list of AclEntry which represent this ACL instance.
getEntries() - Method in class alluxio.security.authorization.DefaultAccessControlList
Returns a list of AclEntry which represent this ACL instance.
getEntries() - Method in class alluxio.security.authorization.ExtendedACLEntries
Returns a list of AclEntry which represent this ACL instance.
getEntryCount() - Method in class alluxio.wire.BackupStatus
 
getEntryMap() - Method in class alluxio.collections.LockPool
 
getEnum(PropertyKey, Class<T>) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the value for the given key as an enum value.
getEnum(PropertyKey, Class<T>) - Static method in class alluxio.conf.Configuration
Gets the value for the given key as an enum value.
getEnum(PropertyKey, Class<T>) - Method in class alluxio.conf.InstancedConfiguration
 
getEnum(PropertyKey, Class<T>) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getEnum(PropertyKey, Class<T>) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getEnumType() - Method in class alluxio.conf.PropertyKey
 
getError() - Method in class alluxio.thread.AutopsyThread
Gets the crashing error.
getError() - Method in class alluxio.wire.BackupStatus
 
getException() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Returns the exception thrown by the base computation, or a CancellationException if cancelled, or null if none or if the method has not yet completed.
getExistingDirectoryStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getExistingDirectoryStatus(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
getExistingDirectoryStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getExistingDirectoryStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the directory status.
getExistingDirectoryStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getExistingFileStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getExistingFileStatus(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
getExistingFileStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getExistingFileStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file status.
getExistingFileStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getExistingStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getExistingStatus(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
getExistingStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getExistingStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file or directory status.
getExistingStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getExitCode() - Method in class alluxio.shell.CommandReturn
Gets the exit code.
getExitCode() - Method in exception alluxio.util.ShellUtils.ExitCodeException
Gets the exit code.
getExtendedEntries() - Method in class alluxio.security.authorization.AccessControlList
 
getFactory() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the factory used for constructing new workers.
getFailedMasterInfos() - Method in class alluxio.wire.MasterWebUIMasters
Get failed master infos master info [ ].
getFailedNodeInfos() - Method in class alluxio.wire.MasterWebUIWorkers
Get failed node infos node info [ ].
getFatalError() - Method in class alluxio.wire.MasterWebUIBrowse
Gets fatal error.
getFatalError() - Method in class alluxio.wire.MasterWebUIData
Gets fatal error.
getFatalError() - Method in class alluxio.wire.MasterWebUILogs
Gets fatal error.
getFatalError() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets fatal error.
getFatalError() - Method in class alluxio.wire.WorkerWebUILogs
Gets fatal error.
getFieldValue(T) - Method in class alluxio.collections.IndexDefinition
Gets the value of the field that serves as index.
getFIFO() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getFileBlockInfo(long) - Method in class alluxio.wire.FileInfo
 
getFileBlockInfos() - Method in class alluxio.client.file.URIStatus
 
getFileBlockInfos() - Method in class alluxio.wire.FileInfo
 
getFileBlocks() - Method in class alluxio.wire.MasterWebUIBrowse
Gets file blocks.
getFileBlocksOnTier() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets file blocks on tier.
getFileCount() - Method in class alluxio.client.file.ListStatusPartialResult
 
getFileData() - Method in class alluxio.wire.MasterWebUIBrowse
Gets file data.
getFileData() - Method in class alluxio.wire.MasterWebUILogs
Gets file data.
getFileData() - Method in class alluxio.wire.WorkerWebUILogs
Gets file data.
getFileDoesNotExistException() - Method in class alluxio.wire.MasterWebUIBrowse
Gets file does not exist exception.
getFileId() - Method in class alluxio.client.file.URIStatus
 
getFileId() - Method in class alluxio.wire.FileInfo
 
getFileId() - Method in class alluxio.wire.PersistFile
 
getFileId(long) - Static method in class alluxio.master.block.BlockId
 
getFileInfo() - Method in class alluxio.client.file.URIStatus
This is an experimental API.
getFileInfo(long) - Method in interface alluxio.worker.block.BlockWorker
Gets the file information.
getFileInfo(String, GetStatusPOptions) - Method in interface alluxio.worker.dora.DoraWorker
Gets the file information.
getFileInfos() - Method in class alluxio.wire.MasterWebUIBrowse
Gets file infos.
getFileInfos() - Method in class alluxio.wire.MasterWebUIData
Gets file infos.
getFileInfos() - Method in class alluxio.wire.MasterWebUILogs
Gets file infos.
getFileInfos() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets file infos.
getFileInfos() - Method in class alluxio.wire.WorkerWebUILogs
Gets file infos.
getFileLocations() - Method in class alluxio.util.webui.UIFileInfo
Gets file locations.
getFileLocations(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getFileLocations(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getFileLocations(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the list of locations of the indicated path.
getFileLocations(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getFileLocations(String, FileLocationOptions) - Method in interface alluxio.underfs.UnderFileSystem
Gets the list of locations of the indicated path given options.
getFileLocations(String, FileLocationOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFilePath() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
getFileStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getFileStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getFileStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file status.
getFileStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFilesToPersist() - Method in class alluxio.wire.PersistCommandOptions
 
getFilterMetricName() - Method in class alluxio.metrics.aggregator.SingleTagValueAggregator
 
getFilterMetricName() - Method in interface alluxio.metrics.MultiValueMetricsAggregator
 
getFilters() - Method in interface alluxio.metrics.MetricsAggregator
 
getFingerprint(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getFingerprint(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
getFingerprint(String) - Method in interface alluxio.underfs.UnderFileSystem
Deprecated. 
getFingerprint(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getFirst() - Method in class alluxio.collections.Pair
 
getFirst(V) - Method in interface alluxio.collections.FieldIndex
Gets an object from the set of objects with the specified field value.
getFirst(V) - Method in class alluxio.collections.NonUniqueFieldIndex
 
getFirst(V) - Method in class alluxio.collections.UniqueFieldIndex
 
getFirstByField(IndexDefinition<T, V>, V) - Method in class alluxio.collections.IndexedSet
Gets the object from the set of objects with the specified field value.
getFolderSuffix() - Method in class alluxio.underfs.ObjectUnderFileSystem
Get suffix used to encode a directory.
getForkJoinTaskTag() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Returns the tag for this task.
getFormattedOutput() - Method in class alluxio.shell.CommandReturn
Formats the object to more readable format.
getFqdnHost(WorkerNetAddress) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets FQDN(Full Qualified Domain Name) from Alluxio representation of network address.
getFqdnHost(InetSocketAddress) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets FQDN(Full Qualified Domain Name) from Java representations of network address, except String representation which should be handled by NetworkAddressUtils.resolveHostName(String) which will handle the situation where hostname is null.
getFreeBytes() - Method in class alluxio.wire.BlockMasterInfo
 
getFreeCapacity() - Method in class alluxio.util.webui.StorageTierInfo
Gets free capacity.
getFreeCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets free capacity.
getFreeSpacePercent() - Method in class alluxio.util.webui.NodeInfo
Gets free space percent.
getFreeSpacePercent() - Method in class alluxio.util.webui.StorageTierInfo
Gets free space percent.
getFsType() - Method in class alluxio.util.UnixMountInfo
 
getFullMetricName() - Method in class alluxio.metrics.Metric
 
getGcExecutor() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getGcIntervalMs() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getGroup() - Method in class alluxio.client.file.URIStatus
 
getGroup() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
 
getGroup() - Method in class alluxio.underfs.options.CreateOptions
 
getGroup() - Method in class alluxio.underfs.options.MkdirsOptions
 
getGroup() - Method in class alluxio.underfs.UfsStatus
Gets the group of the given path.
getGroup() - Method in class alluxio.util.webui.UIFileInfo
Gets group.
getGroup() - Method in class alluxio.wire.FileInfo
 
getGroup(UserState, AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
 
getGroupBits() - Method in class alluxio.security.authorization.Mode
 
getGroupFromGrpcClient(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
 
getGroups(String) - Method in class alluxio.security.group.CachedGroupMapping
 
getGroups(String) - Method in interface alluxio.security.group.GroupMappingService
Gets all various group memberships of a given user.
getGroups(String) - Method in class alluxio.security.group.provider.IdentityUserGroupsMapping
Returns list of groups for a user.
getGroups(String) - Method in class alluxio.security.group.provider.ShellBasedUnixGroupsMapping
Returns list of groups for a user.
getGroups(String, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
Using CachedGroupMapping to get the group list of a user.
getGroupsForUserCommand(String) - Static method in class alluxio.util.ShellUtils
Gets a Unix command to get a given user's groups list.
getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.AbstractMasterSelectionPolicy
 
getGrpcMasterAddress(MasterInquireClient) - Method in interface alluxio.master.selectionpolicy.MasterSelectionPolicy
Gets the master address the client makes gRPC request to.
getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.SelectionPolicyAnyMaster
 
getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.SelectionPolicyAnyStandbyMaster
 
getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.SelectionPolicyPrimaryMaster
 
getGrpcMasterAddress(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.SelectionPolicySpecifiedMaster
 
getHeadDelay() - Method in class alluxio.util.executor.ControllableQueue
 
getHeadValue() - Method in class alluxio.util.executor.ControllableQueue
 
getHighestTierAlias() - Method in class alluxio.wire.MasterWebUIBrowse
Gets highest tier alias.
getHiveCacheContext() - Method in class alluxio.client.file.CacheContext
 
getHost() - Method in class alluxio.uri.SingleMasterAuthority
 
getHost() - Method in class alluxio.util.webui.NodeInfo
Gets host.
getHost() - Method in class alluxio.wire.Address
 
getHost() - Method in class alluxio.wire.WorkerNetAddress
 
getHostname() - Method in class alluxio.wire.BackupStatus
 
getHostName() - Method in class alluxio.grpc.GrpcServerAddress
 
getHostName() - Method in class alluxio.shell.ScpCommand
Returns the remote target hostname.
getHostName() - Method in class alluxio.shell.SshCommand
Returns the remote target hostname.
getHostNameKey() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
Gets the key of connect hostname.
getHostNameKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the key of connect hostname.
getId() - Method in enum alluxio.network.protocol.RPCMessage.Type
Returns the int identifier of the type.
getId() - Method in class alluxio.util.webui.UIFileInfo
Gets id.
getId() - Method in class alluxio.util.webui.UIMasterInfo
Get id.
getId() - Method in class alluxio.wire.BlockReadRequest
 
getId() - Method in class alluxio.wire.MasterInfo
 
getId() - Method in class alluxio.wire.WorkerInfo
 
getID() - Method in class alluxio.util.webui.UIFileBlockInfo
Gets id.
getIdentifier() - Method in class alluxio.master.file.meta.xattr.AbstractExtendedAttribute
 
getIdentifier() - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
 
getImpersonationUser(Subject, AlluxioConfiguration) - Static method in class alluxio.security.authentication.AuthenticationUtils
 
getInAlluxio() - Method in class alluxio.util.webui.UIFileInfo
Gets in alluxio.
getInAlluxioFileNum() - Method in class alluxio.wire.MasterWebUIData
Gets in alluxio file num.
getInAlluxioPercentage() - Method in class alluxio.client.file.URIStatus
 
getInAlluxioPercentage() - Method in class alluxio.util.webui.UIFileInfo
Gets in alluxio percentage.
getInAlluxioPercentage() - Method in class alluxio.wire.FileInfo
 
getIncreasingByteArray(int) - Static method in class alluxio.util.io.BufferUtils
Gets an increasing sequence of bytes starting at zero.
getIncreasingByteArray(int, int) - Static method in class alluxio.util.io.BufferUtils
Gets an increasing sequence of bytes starting with the given value.
getIncreasingByteBuffer(int) - Static method in class alluxio.util.io.BufferUtils
Gets a ByteBuffer containing an increasing sequence of bytes starting at zero.
getIncreasingByteBuffer(int, int) - Static method in class alluxio.util.io.BufferUtils
Gets a ByteBuffer containing an increasing sequence of bytes starting at the given value.
getInfoTimeExceeded() - Method in class alluxio.util.JvmPauseMonitor
 
getInitialBytes() - Method in class alluxio.worker.block.CreateBlockOptions
 
getInitialDelayMs() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getInMemoryPercentage() - Method in class alluxio.client.file.URIStatus
 
getInMemoryPercentage() - Method in class alluxio.wire.FileInfo
 
getInputStream(String, Integer) - Static method in class alluxio.util.network.HttpUtils
Uses the get method to send a url with arguments by http, this method can call RESTful Api.
getInstanceType() - Method in class alluxio.metrics.Metric
 
getInstanceType() - Method in class alluxio.metrics.MetricsFilter
 
getInt(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the integer representation of the value for the given key.
getInt(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the integer representation of the value for the given key.
getInt(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getInt(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getInt(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getInterval() - Method in class alluxio.util.WaitForOptions
 
getInvalidPathError() - Method in class alluxio.wire.MasterWebUIBrowse
Gets invalid path error.
getInvalidPathError() - Method in class alluxio.wire.MasterWebUILogs
Gets invalid path error.
getInvalidPathError() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets invalid path error.
getInvalidPathError() - Method in class alluxio.wire.WorkerWebUILogs
Gets invalid path error.
getInvalidPathException() - Method in class alluxio.wire.MasterWebUIBrowse
Gets invalid path exception.
getIpAddress() - Static method in class alluxio.security.authentication.ClientIpAddressInjector
 
getIsDirectory() - Method in class alluxio.util.webui.UIFileInfo
Gets is directory.
getIsInHighestTier() - Method in class alluxio.util.webui.UIFileBlockInfo
Gets whether the block is in the highest tier alias.
getJavaVersion() - Static method in class alluxio.util.CommonUtils
 
getJobMasterEmbeddedJournalAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
getJobMasterHostNotConfiguredMessage(String) - Static method in class alluxio.util.ConfigurationUtils
Returns a unified message for cases when the job master hostname cannot be determined.
getJobMasterRpcAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
Gets the RPC addresses of all job masters based on the configuration.
getJobWorkerMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
Builds metric registry name for job worker instance.
getJournal(URI) - Method in interface alluxio.underfs.UfsManager
 
getJournalCheckpointTimeWarning() - Method in class alluxio.wire.MasterWebUIOverview
 
getJournalDiskMetrics() - Method in class alluxio.wire.MasterWebUIMetrics
 
getJournalDiskWarnings() - Method in class alluxio.wire.MasterWebUIOverview
 
getJournalEntriesSinceCheckpoint() - Method in class alluxio.wire.MasterWebUIMetrics
 
getJournalLastCheckpointTime() - Method in class alluxio.wire.MasterWebUIMetrics
 
getLastAccessTimeMs() - Method in class alluxio.client.file.URIStatus
 
getLastAccessTimeMs() - Method in class alluxio.resource.DynamicResourcePool.ResourceInternal
 
getLastAccessTimeMs() - Method in class alluxio.util.webui.UIFileBlockInfo
Gets last access time ms.
getLastAccessTimeMs() - Method in class alluxio.wire.FileInfo
 
getLastContactSec() - Method in class alluxio.wire.WorkerInfo
 
getLastHeartbeat() - Method in class alluxio.util.webui.NodeInfo
Gets last heartbeat.
getLastModificationTimeMs() - Method in class alluxio.client.file.URIStatus
 
getLastModificationTimeMs() - Method in class alluxio.wire.FileInfo
 
getLastModifiedTime() - Method in class alluxio.underfs.UfsStatus
Gets the UTC time of when the indicated path was modified recently in ms, or null if the last modified time is not available.
getLastModifiedTimeMs() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
Gets the last modified epoch time in ms.
getLastUpdatedTime() - Method in class alluxio.util.webui.UIMasterInfo
Get master last update time.
getLastUpdatedTimeMs() - Method in class alluxio.wire.MasterInfo
 
getLatestVersion(String, List<String>, long, long, long) - Static method in class alluxio.check.UpdateCheck
 
getLeaderId() - Method in class alluxio.wire.MasterWebUIOverview
Gets leader id.
getLeaderMasterInfo() - Method in class alluxio.wire.MasterWebUIMasters
Get normal master infos master info [ ].
getLeaderPath() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
getLeadingPath(int) - Method in class alluxio.AlluxioURI
Gets the first n components of the AlluxioURI path.
getLeafChildren(String) - Method in class alluxio.conf.path.TrieNode
Get the terminal children of path (including path).
getLength() - Method in class alluxio.client.file.URIStatus
 
getLength() - Method in class alluxio.grpc.ReadableDataBuffer
 
getLength() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Returns the length of the data.
getLength() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
getLength() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
getLength() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
getLength() - Method in class alluxio.underfs.options.OpenOptions
 
getLength() - Method in class alluxio.wire.BlockInfo
 
getLength() - Method in class alluxio.wire.FileInfo
 
getLength() - Method in class alluxio.worker.block.io.BlockReader
Gets the length of the block in bytes.
getLength() - Method in class alluxio.worker.block.io.DelegatingBlockReader
 
getLength() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
getLevel() - Method in class alluxio.wire.LogInfo
 
getList() - Method in class alluxio.collections.PrefixList
Gets the list of prefixes.
getList(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the value for the given key as a list.
getList(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the value for the given key as a list.
getList(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getList(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getList(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getListingChunkLength(AlluxioConfiguration) - Method in class alluxio.underfs.ObjectUnderFileSystem
The number of items to query in a single listing chunk.
getListingChunkLengthMax() - Method in class alluxio.underfs.ObjectUnderFileSystem
Maximum number of items in a single listing chunk supported by the under store.
getListings() - Method in class alluxio.client.file.ListStatusPartialResult
 
getLiveWorkerNodes() - Method in class alluxio.wire.MasterWebUIOverview
Gets live worker nodes.
getLiveWorkerNum() - Method in class alluxio.wire.BlockMasterInfo
 
getLocalFileGroup(String) - Static method in class alluxio.util.io.FileUtils
Gets local file's group.
getLocalFileMode(String) - Static method in class alluxio.util.io.FileUtils
Gets local file's permission mode.
getLocalFileOwner(String) - Static method in class alluxio.util.io.FileUtils
Gets local file's owner.
getLocalHostMetricName(int) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local hostname for the host this JVM is running on with '.' replaced with '_' for metrics usage.
getLocalHostName(int) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local host name for the host this JVM is running on.
getLocalIpAddress(int) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local IP address for the host this JVM is running on.
getLocalNodeName(AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets a local node name from configuration if it is available, falling back on localhost lookup.
getLocation() - Method in class alluxio.worker.block.AllocateOptions
 
getLocation() - Method in class alluxio.worker.block.io.BlockReader
 
getLocation() - Method in class alluxio.worker.block.io.DelegatingBlockReader
 
getLocation() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
getLocations() - Method in class alluxio.util.webui.UIFileBlockInfo
Gets locations.
getLocations() - Method in class alluxio.wire.BlockInfo
 
getLocations() - Method in class alluxio.wire.BlockLocationInfo
 
getLogicalName() - Method in class alluxio.uri.EmbeddedLogicalAuthority
 
getLogicalName() - Method in class alluxio.uri.ZookeeperLogicalAuthority
 
getLogName() - Method in class alluxio.wire.LogInfo
 
getLong(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the long integer representation of the value for the given key.
getLong(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the long integer representation of the value for the given key.
getLong(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getLong(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getLong(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getLostStorage() - Method in class alluxio.worker.block.BlockHeartbeatReport
Gets the storage paths which were lost in the heartbeat this report represents.
getLostStorage() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getLostStorage() - Method in interface alluxio.worker.block.meta.StorageTier
 
getLostWorkerNum() - Method in class alluxio.wire.BlockMasterInfo
 
getLostWorkers() - Method in class alluxio.wire.AlluxioMasterInfo
 
getMask() - Method in class alluxio.security.authorization.ExtendedACLEntries
 
getMasterAddresses() - Method in class alluxio.uri.MultiMasterAuthority
 
getMasterCapacityFreePercentage() - Method in class alluxio.wire.MasterWebUIMetrics
Gets master capacity free percentage.
getMasterCapacityUsedPercentage() - Method in class alluxio.wire.MasterWebUIMetrics
Gets master capacity used percentage.
getMasterEmbeddedJournalAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
getMasterHostname() - Method in class alluxio.wire.WorkerWebUIInit
Gets master ip.
getMasterHostnames(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
Gets list of masters in conf directory.
getMasterHostNotConfiguredMessage(String) - Static method in class alluxio.util.ConfigurationUtils
Returns a unified message for cases when the master hostname cannot be determined.
getMasterInquireClient() - Method in class alluxio.master.MasterClientContext
 
getMasterMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
Builds metric registry names for master instance.
getMasterMetrics(Set<String>) - Static method in class alluxio.metrics.MetricsSystem
Gets all the master metrics belongs to the given metric names.
getMasterNodeAddress() - Method in class alluxio.wire.MasterWebUIBrowse
Gets master node address.
getMasterNodeAddress() - Method in class alluxio.wire.MasterWebUIData
Gets master node address.
getMasterNodeAddress() - Method in class alluxio.wire.MasterWebUIOverview
Gets master node address.
getMasterPort() - Method in class alluxio.wire.WorkerWebUIInit
Gets master port.
getMasterRole() - Method in class alluxio.wire.MasterWebUIOverview
Gets master role name.
getMasterRpcAddresses() - Method in interface alluxio.master.MasterInquireClient
 
getMasterRpcAddresses() - Method in class alluxio.master.PollingMasterInquireClient
 
getMasterRpcAddresses() - Method in class alluxio.master.SingleMasterInquireClient
 
getMasterRpcAddresses() - Method in class alluxio.master.ZkMasterInquireClient
 
getMasterRpcAddresses(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
Gets the RPC addresses of all masters based on the configuration.
getMasterUnderfsCapacityFreePercentage() - Method in class alluxio.wire.MasterWebUIMetrics
Gets master underfs capacity free percentage.
getMasterUnderfsCapacityUsedPercentage() - Method in class alluxio.wire.MasterWebUIMetrics
Gets master underfs capacity used percentage.
getMaxCapacity() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getMaxSequenceNumber() - Static method in class alluxio.master.block.BlockId
 
getMechanismName() - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
getMechanismNames(Map<String, ?>) - Method in class alluxio.security.authentication.plain.PlainSaslServer.Factory
 
getMedium() - Method in class alluxio.worker.block.CreateBlockOptions
 
getMediumType() - Method in class alluxio.wire.BlockLocation
 
getMediumTypes() - Method in class alluxio.wire.FileInfo
 
getMemoryPoolNames() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
 
getMessage() - Method in exception alluxio.exception.AggregateException
 
getMessage() - Method in exception alluxio.exception.runtime.AlluxioRuntimeException
 
getMessage() - Method in class alluxio.grpc.DataMessage
 
getMessage() - Method in class alluxio.network.protocol.RPCProtoMessage
 
getMessage() - Method in class alluxio.wire.LogInfo
 
getMessage(Object...) - Method in enum alluxio.exception.ExceptionMessage
Formats the message of the exception.
getMessage(String) - Static method in class alluxio.conf.RemovedKey
gets the message pertaining to a removed key or template.
getMessageWithUrl(String, Object...) - Method in enum alluxio.exception.ExceptionMessage
Formats the message of the exception with an url to consult.
getMetricCounter() - Method in class alluxio.network.netty.NettyChannelPool
 
getMetricCounter() - Method in class alluxio.resource.DynamicResourcePool
 
getMetricName() - Method in class alluxio.metrics.MetricKey
 
getMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
Converts a simple string to a qualified metric name based on the process type.
getMetricNameWithTags(String, String...) - Static method in class alluxio.metrics.Metric
Gets the metric name with the appendix of tags.
getMetricNameWithUserTag(String, String) - Static method in class alluxio.metrics.Metric
Gets a metric name with a specific user tag.
getMetricRegistry() - Method in class alluxio.metrics.source.JvmSource
 
getMetricRegistry() - Method in interface alluxio.metrics.source.Source
Gets the instance of the MetricRegistry.
getMetrics() - Method in class alluxio.metrics.OperationSystemGaugeSet
 
getMetrics() - Method in class alluxio.wire.AlluxioMasterInfo
 
getMetrics() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getMetricType() - Method in class alluxio.metrics.Metric
 
getMetricType() - Method in class alluxio.metrics.MetricKey
 
getMetricValue(String) - Static method in class alluxio.metrics.MetricsSystem
Gets metric with the given full metric name.
getMinCapacity() - Method in class alluxio.resource.DynamicResourcePool.Options
 
getMode() - Method in class alluxio.client.file.URIStatus
 
getMode() - Method in class alluxio.security.authorization.AccessControlList
 
getMode() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
 
getMode() - Method in class alluxio.underfs.options.CreateOptions
 
getMode() - Method in class alluxio.underfs.options.MkdirsOptions
 
getMode() - Method in class alluxio.underfs.UfsStatus
Gets the mode of the given path in short format, e.g 0700.
getMode() - Method in class alluxio.util.webui.UIFileInfo
Gets mode.
getMode() - Method in class alluxio.wire.FileInfo
 
getModificationTime() - Method in class alluxio.util.webui.UIFileInfo
Gets modification time.
getMountId() - Method in class alluxio.client.file.URIStatus
 
getMountId() - Method in class alluxio.wire.FileInfo
 
getMountId() - Method in class alluxio.wire.MountPointInfo
 
getMountOptions() - Method in class alluxio.wire.UfsInfo
 
getMountPath() - Method in class alluxio.wire.JournalDiskInfo
 
getMountPoint() - Method in class alluxio.util.UnixMountInfo
 
getMountPoint() - Method in class alluxio.util.webui.UIMountPointInfo
Gets mount point.
getMountPointInfos() - Method in class alluxio.wire.MasterWebUIMountTable
Get mount point infos [ ].
getMountPoints() - Method in class alluxio.wire.AlluxioMasterInfo
 
getMountSpecificConf() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getMs(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the time of key in millisecond unit.
getMs(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the time of key in millisecond unit.
getMs(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getMs(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getMs(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getName() - Method in class alluxio.AlluxioURI
Gets the final component of the AlluxioURI.
getName() - Method in interface alluxio.cli.ValidationTask
Gets the name of the task.
getName() - Method in class alluxio.cli.ValidationTaskResult
 
getName() - Method in class alluxio.client.file.URIStatus
For example for the uri: alluxio://host:1000/foo/bar/baz, baz is the name.
getName() - Method in class alluxio.conf.PropertyKey
 
getName() - Method in class alluxio.master.file.meta.xattr.AbstractExtendedAttribute
 
getName() - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
 
getName() - Method in class alluxio.metrics.Metric
 
getName() - Method in class alluxio.metrics.MetricKey
 
getName() - Method in interface alluxio.metrics.MetricsAggregator
 
getName() - Method in class alluxio.metrics.MetricsFilter
 
getName() - Method in class alluxio.metrics.source.JvmSource
 
getName() - Method in interface alluxio.metrics.source.Source
Gets the name of the Source.
getName() - Method in class alluxio.metrics.TimeSeries
 
getName() - Method in class alluxio.security.CurrentUser
 
getName() - Method in class alluxio.security.User
 
getName() - Method in interface alluxio.Server
 
getName() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
Gets the name of the object.
getName() - Method in class alluxio.underfs.UfsStatus
 
getName() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
 
getName() - Method in class alluxio.util.logging.SamplingLogger
 
getName() - Method in class alluxio.util.webui.UIFileInfo
Gets name.
getName() - Method in class alluxio.wire.FileInfo
 
getName() - Method in class alluxio.wire.InconsistentProperty
 
getName() - Method in class alluxio.wire.Property
 
getNamedGroup(String) - Method in class alluxio.security.authorization.ExtendedACLEntries
 
getNamedGroupActions() - Method in class alluxio.security.authorization.ExtendedACLEntries
 
getNamedGroupsProto(ExtendedACLEntries) - Static method in class alluxio.util.proto.ProtoUtils
 
getNamedUser(String) - Method in class alluxio.security.authorization.ExtendedACLEntries
 
getNamedUserActions() - Method in class alluxio.security.authorization.ExtendedACLEntries
 
getNamedUsersProto(ExtendedACLEntries) - Static method in class alluxio.util.proto.ProtoUtils
 
getNamespace() - Method in class alluxio.master.file.meta.xattr.AbstractExtendedAttribute
 
getNamespace() - Method in interface alluxio.master.file.meta.xattr.ExtendedAttribute
 
getNegotiatedProperty(String) - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
getNestedProperties(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets a set of properties that share a given common prefix key as a map.
getNestedProperties(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets a set of properties that share a given common prefix key as a map.
getNestedProperties(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getNestedProperties(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getNestedProperties(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getNettyDataPort() - Method in class alluxio.wire.WorkerNetAddress
 
getNettyOutput() - Method in class alluxio.grpc.ReadableDataBuffer
 
getNettyOutput() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Returns an object for writing to a netty channel.
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
getNettyOutput() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
getNetworkGroup() - Method in class alluxio.grpc.GrpcChannelKey
 
getNewerVersionAvailable() - Method in class alluxio.wire.MasterWebUIInit
Gets newer version available.
getNextChunk() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Gets next chunk of object listings.
getNormalMasterInfos() - Method in class alluxio.wire.MasterWebUIMasters
Get leader master info master info.
getNormalNodeInfos() - Method in class alluxio.wire.MasterWebUIWorkers
Get normal node infos node info [ ].
getNow(T) - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns the result value (or throws any encountered exception) if completed, else returns the given valueIfAbsent.
getNTotalFile() - Method in class alluxio.wire.MasterWebUIBrowse
Gets n total file.
getNTotalFile() - Method in class alluxio.wire.MasterWebUILogs
Gets n total file.
getNTotalFile() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets n total file.
getNTotalFile() - Method in class alluxio.wire.WorkerWebUILogs
Gets n total file.
getNumberOfBlocks() - Method in interface alluxio.worker.block.BlockStoreMeta
Note: This is only available when blocks are included.
getNumberOfDependents() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns the estimated number of CompletableFutures whose completions are awaiting completion of this CompletableFuture.
getNumEvents() - Method in class alluxio.time.ExponentialTimer
 
getNumSector(String, String) - Static method in class alluxio.util.HFSUtils
Converts the memory size to number of sectors.
getNumSinks() - Static method in class alluxio.metrics.MetricsSystem
 
getObjectHeaderSize() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
Returns the fixed overhead of for any Object subclass in this JVM.
getObjectListingChunk(String, boolean) - Method in class alluxio.underfs.ObjectUnderFileSystem
Gets a (partial) object listing result for the given key.
getObjectListingChunkForPath(String, boolean) - Method in class alluxio.underfs.ObjectUnderFileSystem
Gets a (partial) object listing for the given path.
getObjectName() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
 
getObjectPadding() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
Returns the quantum field size for a field owned by an object in this JVM.
getObjectSize(Object) - Static method in class alluxio.util.ObjectSizeCalculator
Given an object, returns the total allocated size, in bytes, of the object and all other objects reachable from it.
getObjectSize(Object, Set<Class<?>>) - Static method in class alluxio.util.ObjectSizeCalculator
Given an object, returns the total allocated size, in bytes, of the object and all other objects reachable from it.
getObjectStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Get metadata information about object.
getObjectStatuses() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectListingChunk
Returns objects in a pseudo-directory which may be a file or a directory.
getOffset() - Method in class alluxio.underfs.options.FileLocationOptions
 
getOffset() - Method in class alluxio.underfs.options.OpenOptions
 
getOffset() - Method in class alluxio.wire.FileBlockInfo
 
getOnTierPercentages() - Method in class alluxio.util.webui.UIFileInfo
Gets on-tier percentages.
getOpenUfsBlockOptions() - Method in class alluxio.wire.BlockReadRequest
 
getOperationMetrics() - Method in class alluxio.wire.MasterWebUIMetrics
Gets operation metrics.
getOperationMetrics() - Method in class alluxio.wire.WorkerWebUIMetrics
Gets operation metrics.
getOperationMode(Map<String, UfsMode>) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getOperationMode(Map<String, UfsMode>) - Method in class alluxio.underfs.BaseUnderFileSystem
 
getOperationMode(Map<String, UfsMode>) - Method in interface alluxio.underfs.UnderFileSystem
An UnderFileSystem may be composed of one or more "physical UFS"s.
getOperationMode(Map<String, UfsMode>) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getOptionList() - Method in class alluxio.cli.AbstractValidationTask
 
getOptionList() - Method in interface alluxio.cli.ValidationTask
 
getOptions() - Method in interface alluxio.cli.Command
 
getOptions() - Method in class alluxio.job.CopyJobRequest
 
getOptions() - Method in class alluxio.job.LoadJobRequest
 
getOptions() - Method in class alluxio.util.UnixMountInfo
 
getOrBuildCustom(String) - Static method in class alluxio.conf.PropertyKey
 
getOrDefault(PropertyKey, Object, ConfigurationValueOptions) - Method in interface alluxio.conf.AlluxioConfiguration
 
getOrDefault(PropertyKey, String, ConfigurationValueOptions) - Static method in class alluxio.conf.Configuration
 
getOrDefault(PropertyKey, T) - Method in interface alluxio.conf.AlluxioConfiguration
 
getOrDefault(PropertyKey, T) - Static method in class alluxio.conf.Configuration
 
getOrderedStorageAliases() - Method in interface alluxio.StorageTierAssoc
 
getOrderedTierAliases() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets ordered tier aliases.
getOrdinal(String) - Method in interface alluxio.StorageTierAssoc
 
getOrNull() - Static method in class alluxio.security.authentication.AuthenticatedClientUser
 
getOtherActions() - Method in class alluxio.security.authorization.AccessControlList
 
getOtherBits() - Method in class alluxio.security.authorization.Mode
 
getOutput() - Method in class alluxio.shell.CommandReturn
Gets the stdout content.
getOverheadRatio() - Method in enum alluxio.client.file.cache.store.PageStoreType
 
getOwner() - Method in class alluxio.client.file.URIStatus
 
getOwner() - Method in class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
 
getOwner() - Method in class alluxio.underfs.options.CreateOptions
 
getOwner() - Method in class alluxio.underfs.options.MkdirsOptions
 
getOwner() - Method in class alluxio.underfs.UfsStatus
Gets the owner of the given path.
getOwner() - Method in class alluxio.util.webui.UIFileInfo
Gets owner.
getOwner() - Method in class alluxio.wire.FileInfo
 
getOwner(UserState) - Static method in class alluxio.util.SecurityUtils
 
getOwnerBits() - Method in class alluxio.security.authorization.Mode
 
getOwnerFromGrpcClient(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
 
getOwningGroup() - Method in class alluxio.security.authorization.AccessControlList
 
getOwningGroupActions() - Method in class alluxio.security.authorization.AccessControlList
 
getOwningUser() - Method in class alluxio.security.authorization.AccessControlList
 
getOwningUserActions() - Method in class alluxio.security.authorization.AccessControlList
 
getParallelism() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the targeted parallelism level of this pool.
getParent() - Method in class alluxio.AlluxioURI
Get the parent of this AlluxioURI or null if at root.
getParent(String) - Static method in class alluxio.util.io.PathUtils
Gets the parent of the file at a path.
getParentCleaned(String) - Static method in class alluxio.util.io.PathUtils
The same as PathUtils.getParent(java.lang.String) except does not clean the path before getting the parent.
getParentDir() - Method in interface alluxio.worker.block.meta.BlockMeta
 
getParentDir() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getParentPath(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Get parent path.
getParents() - Method in class alluxio.collections.DirectedAcyclicGraphNode
Gets the parent nodes of the node.
getParents(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Gets the payloads for the given nodes parents.
getParentTier() - Method in interface alluxio.worker.block.meta.StorageDir
Returns the StorageTier containing this StorageDir.
getParsedFingerprint(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getParsedFingerprint(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
getParsedFingerprint(String) - Method in interface alluxio.underfs.UnderFileSystem
Computes and returns a fingerprint for the path.
getParsedFingerprint(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getPartition() - Method in class alluxio.client.hive.HiveCacheContext
 
getPartNumber() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
Get the part number.
getPath() - Method in class alluxio.AlluxioURI
Gets the path component of the AlluxioURI.
getPath() - Method in class alluxio.client.file.URIStatus
For example, for the uri: alluxio://host:1000/foo/bar/baz, the path is /foo/bar/baz.
getPath() - Method in class alluxio.job.JobDescription
 
getPath() - Method in class alluxio.job.LoadJobRequest
 
getPath() - Method in class alluxio.uri.StandardURI
 
getPath() - Method in interface alluxio.uri.URI
 
getPath() - Method in class alluxio.wire.FileInfo
 
getPath() - Method in class alluxio.wire.WorkerWebUIBlockInfo
Gets path.
getPath() - Method in interface alluxio.worker.block.meta.BlockMeta
 
getPath() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getPathComponents(String) - Static method in class alluxio.util.io.PathUtils
Gets the path components of the given path.
getPathConf() - Method in class alluxio.ClientContext
 
getPathConf() - Method in class alluxio.wire.Configuration
 
getPathConf(GetConfigurationPResponse, AlluxioConfiguration) - Static method in class alluxio.conf.Configuration
Loads the path level configuration from the get configuration response.
getPathConfHash() - Method in class alluxio.ClientContext
 
getPathConfHash() - Method in class alluxio.wire.Configuration
 
getPathConfigHash() - Method in class alluxio.wire.ConfigHash
 
getPathInfos() - Method in class alluxio.wire.MasterWebUIBrowse
Get path infos ui file info [ ].
getPayload() - Method in class alluxio.collections.DirectedAcyclicGraphNode
Gets the payload of the node.
getPayloadDataBuffer() - Method in class alluxio.network.protocol.RPCMessage
Returns the data buffer of the payload.
getPayloadDataBuffer() - Method in class alluxio.network.protocol.RPCProtoMessage
 
getPendingCount() - Method in class alluxio.concurrent.jsr.CountedCompleter
Returns the current pending count.
getPercentAvailable() - Method in class alluxio.wire.JournalDiskInfo
 
getPermanentFileName(String) - Static method in class alluxio.util.io.PathUtils
 
getPermission(String, List<String>) - Method in class alluxio.security.authorization.AccessControlList
Gets the permitted actions for a user.
getPermissionError() - Method in class alluxio.wire.MasterWebUIData
Gets permission error.
getPermissions() - Method in class alluxio.underfs.ObjectUnderFileSystem
Permissions for the mounted bucket.
getPersistenceState() - Method in class alluxio.client.file.URIStatus
 
getPersistenceState() - Method in class alluxio.util.webui.UIFileInfo
Gets persistence state.
getPersistenceState() - Method in class alluxio.wire.FileInfo
 
getPersistentTmpPath(AlluxioConfiguration, String) - Static method in class alluxio.util.io.PathUtils
Get temp path for async persistence job.
getPersistOptions() - Method in class alluxio.wire.FileSystemCommandOptions
 
getPhysicalStores() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getPhysicalStores() - Method in class alluxio.underfs.BaseUnderFileSystem
 
getPhysicalStores() - Method in interface alluxio.underfs.UnderFileSystem
An UnderFileSystem may be composed of one or more "physical UFS"s.
getPhysicalStores() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getPinnedMediumTypes() - Method in class alluxio.client.file.URIStatus
 
getPluginMetricName(String) - Static method in class alluxio.metrics.MetricsSystem
Builds metric registry name for plugin instance.
getPool() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns the pool hosting the current thread, or null if the current thread is executing outside of any ForkJoinPool.
getPool() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
Returns the pool hosting this thread.
getPoolIndex() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
Returns the unique index number of this thread in its pool.
getPoolSize() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the number of worker threads that have started but not yet terminated.
getPort() - Method in class alluxio.uri.SingleMasterAuthority
 
getPort(NetworkAddressUtils.ServiceAttributeProvider, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Gets the port number on a given service type.
getPortKey() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
Gets the key of service port.
getPortKey() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets the key of service port.
getPos() - Method in class alluxio.file.SeekableBufferedInputStream
 
getPos() - Method in interface alluxio.Positioned
 
getPosition() - Method in class alluxio.worker.block.io.BlockWriter
 
getPosition() - Method in class alluxio.worker.block.io.LocalFileBlockWriter
 
getPositionShort() - Method in class alluxio.underfs.options.OpenOptions
 
getPrimaryGroupName(String, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
Gets the primary group name of a user.
getPrimaryMasterAddressCached(MasterInquireClient) - Method in class alluxio.master.selectionpolicy.AbstractMasterSelectionPolicy
 
getPrimaryMasterAddressCached(MasterInquireClient) - Method in interface alluxio.master.selectionpolicy.MasterSelectionPolicy
Get and cache the primary master address.
getPrimaryRpcAddress() - Method in interface alluxio.master.MasterInquireClient
 
getPrimaryRpcAddress() - Method in class alluxio.master.PollingMasterInquireClient
 
getPrimaryRpcAddress() - Method in class alluxio.master.SingleMasterInquireClient
 
getPrimaryRpcAddress() - Method in class alluxio.master.ZkMasterInquireClient
 
getProperties() - Method in class alluxio.conf.InstancedConfiguration
Return reference to mProperties.
getProperties() - Method in class alluxio.metrics.MetricsConfig
 
getProperties() - Method in class alluxio.util.webui.UIMountPointInfo
 
getProperties() - Method in class alluxio.wire.MountPointInfo
 
getPropertyCode() - Method in enum alluxio.grpc.GrpcNetworkGroup
 
getPropertyKeys(AlluxioURI) - Method in interface alluxio.conf.path.PathConfiguration
 
getPropertyKeys(AlluxioURI) - Method in class alluxio.conf.path.PrefixPathConfiguration
 
getProxyDownloadFileApiUrl() - Method in class alluxio.wire.MasterWebUIInit
Gets proxy download file api url.
getQuery() - Method in class alluxio.uri.StandardURI
 
getQuery() - Method in interface alluxio.uri.URI
 
getQueryMap() - Method in class alluxio.AlluxioURI
Gets the map of query parameters.
getQueuedSubmissionCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the number of tasks submitted to this pool that have not yet begun executing.
getQueuedTaskCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the total number of tasks currently held in queues by worker threads (but not including tasks submitted to the pool that have not begun executing).
getQueuedTaskCount() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns an estimate of the number of tasks that have been forked by the current worker thread but not yet executed.
getQuota(CacheScope) - Method in class alluxio.client.quota.CacheQuota
 
getRandomNonNegativeLong() - Static method in class alluxio.util.IdUtils
Generates a positive random number by zero-ing the sign bit.
getRawReadWriteLock(K) - Method in class alluxio.collections.LockPool
Get the raw readwrite lock from the pool.
getRawResult() - Method in class alluxio.concurrent.jsr.CountedCompleter
Returns the result of the computation.
getRawResult() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Returns the result that would be returned by ForkJoinTask.join(), even if this task completed abnormally, or null if this task is not known to have been completed.
getReadOnly() - Method in class alluxio.wire.MountPointInfo
 
getReadOnlyByteBuffer() - Method in class alluxio.grpc.ReadableDataBuffer
 
getReadOnlyByteBuffer() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Returns a ByteBuffer for read-only access to the data.
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
getReadOnlyByteBuffer() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
getRecoverFailedOpen() - Method in class alluxio.underfs.options.OpenOptions
 
getReferenceCount() - Method in class alluxio.concurrent.ClientRWLock
 
getReferenceSize() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
Returns the fixed size of an object reference in this JVM.
getRefreshInterval() - Method in class alluxio.wire.MasterWebUIInit
Gets refresh interval.
getRefreshInterval() - Method in class alluxio.wire.WorkerWebUIInit
Gets refresh interval.
getRemoteHostName() - Method in class alluxio.AbstractClient
 
getRemoteHostName() - Method in interface alluxio.Client
 
getRemoteServiceType() - Method in class alluxio.AbstractClient
 
getRemoteServiceVersion() - Method in class alluxio.AbstractClient
 
getRemoteSockAddress() - Method in class alluxio.AbstractClient
 
getRemoteSockAddress() - Method in interface alluxio.Client
 
getRemovalMessage(String) - Static method in class alluxio.conf.PropertyKey
 
getRemovedBlocks() - Method in class alluxio.worker.block.BlockHeartbeatReport
Gets the list of blocks removed from this worker in the heartbeat this report represents.
getReplicaBlockCount() - Method in class alluxio.wire.MasterWebUIOverview
Gets replica block count.
getReplicationMax() - Method in class alluxio.client.file.URIStatus
 
getReplicationMax() - Method in class alluxio.wire.FileInfo
 
getReplicationMin() - Method in class alluxio.client.file.URIStatus
 
getReplicationMin() - Method in class alluxio.wire.FileInfo
 
getReport() - Method in interface alluxio.worker.block.BlockWorker
Gets a report for the periodic heartbeat to master.
getRequestMarshaller() - Method in class alluxio.grpc.DataMessageMarshallerProvider
 
getReservedBytes() - Method in interface alluxio.worker.block.meta.StorageDir
 
getResourcePoolMetricName(Object) - Static method in class alluxio.metrics.MetricsSystem
Get metrics name based on class.
getResources(String) - Method in class alluxio.extensions.ExtensionsClassLoader
 
getResponseMarshaller() - Method in class alluxio.grpc.DataMessageMarshallerProvider
 
getResult() - Method in class alluxio.cli.ValidationResults
Get Validation Result.
getResult() - Method in class alluxio.cli.ValidationTaskResult
 
getResult() - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Gets the combined result from all batches.
getRevision() - Method in class alluxio.util.webui.NodeInfo
Gets worker revision.
getRevision() - Method in class alluxio.wire.WorkerInfo
 
getRoot() - Method in class alluxio.concurrent.jsr.CountedCompleter
Returns the root of the current computation; i.e., this task if it has no completer, else its completer's root.
getRoot() - Method in interface alluxio.underfs.UfsManager
 
getRootCause(Throwable) - Static method in class alluxio.util.CommonUtils
Gets the root cause of an exception.
getRootKey() - Method in class alluxio.underfs.ObjectUnderFileSystem
Get full path of root in object store.
getRootPath() - Method in class alluxio.AlluxioURI
 
getRoots() - Method in class alluxio.collections.DirectedAcyclicGraph
Gets the payloads of all the root nodes of the DAG.
getRpcAddress() - Method in class alluxio.wire.AlluxioMasterInfo
 
getRpcAddress() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getRpcInvocationMetrics() - Method in class alluxio.wire.MasterWebUIMetrics
Gets rpc invocation metrics.
getRpcPort() - Method in class alluxio.wire.Address
 
getRpcPort() - Method in class alluxio.wire.WorkerNetAddress
 
getRpcPortSocketAddress(WorkerNetAddress, AlluxioConfiguration) - Static method in class alluxio.util.network.NetworkAddressUtils
Extracts rpcPort socket address from Alluxio representation of network address.
getRunningThreadCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the number of worker threads that are not blocked waiting to join tasks or for other managed synchronization.
getScheme() - Method in class alluxio.AlluxioURI
Gets the scheme of the AlluxioURI.
getScheme() - Method in class alluxio.uri.MultiPartSchemeURI
 
getScheme() - Method in class alluxio.uri.StandardURI
 
getScheme() - Method in interface alluxio.uri.URI
 
getSchemeAuthority(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
getSchemeComponents(String) - Static method in class alluxio.uri.URI.Factory
Returns a Pair of components of the given scheme.
getSchemeSpecificPart() - Method in class alluxio.uri.StandardURI
 
getSchemeSpecificPart() - Method in interface alluxio.uri.URI
 
getScope() - Method in class alluxio.conf.PropertyKey
 
getSecond() - Method in class alluxio.collections.Pair
 
getSecurityAuthorizationPermissionEnabled() - Method in class alluxio.wire.MasterWebUIInit
Gets security authorization permission enabled.
getSecurityAuthorizationPermissionEnabled() - Method in class alluxio.wire.WorkerWebUIInit
Gets security authorization permission enabled.
getSelfSignedClientSslContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
 
getSelfSignedClientSslContext() - Method in interface alluxio.util.network.tls.SslContextProvider
 
getSelfSignedServerSslContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
 
getSelfSignedServerSslContext() - Method in interface alluxio.util.network.tls.SslContextProvider
 
getSequenceNumber(long) - Static method in class alluxio.master.block.BlockId
 
getServerAddress() - Method in class alluxio.grpc.GrpcChannelKey
 
getServerChannelClass(boolean, AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
Returns the correct ServerSocketChannel class for use by the worker.
getServerChannelClass(ChannelType, boolean) - Static method in class alluxio.util.network.NettyUtils
Returns the correct ServerSocketChannel class for use by the worker.
getServerHostnames(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
Gets list of masters/workers in conf directory.
getServerSSLContext() - Method in class alluxio.util.network.tls.DefaultSslContextProvider
 
getServerSSLContext() - Method in interface alluxio.util.network.tls.SslContextProvider
 
getServiceDefinition() - Method in class alluxio.grpc.GrpcService
 
getServiceName() - Method in class alluxio.AbstractClient
 
getServiceName() - Method in class alluxio.security.CurrentUser
 
getServiceName() - Method in interface alluxio.util.network.NetworkAddressUtils.ServiceAttributeProvider
Gets service name.
getServiceName() - Method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Gets service name.
getServices() - Method in interface alluxio.Server
 
getServiceVersion() - Method in class alluxio.AbstractClient
 
getServiceVersion(GetServiceVersionPRequest, StreamObserver<GetServiceVersionPResponse>) - Method in class alluxio.grpc.ServiceVersionClientServiceHandler
 
getSessionId() - Method in class alluxio.SessionInfo
 
getSessionId() - Method in class alluxio.wire.BlockReadRequest
 
getSessionId() - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
getSessionTempBlocks(long) - Method in interface alluxio.worker.block.meta.StorageDir
Gets the temporary blocks associated with a session in this StorageDir, an empty list is returned if the session has no temporary blocks in this StorageDir.
getSetPermissionCommand(String, String) - Static method in class alluxio.util.ShellUtils
Returns a Unix command to set permission.
getShared() - Method in class alluxio.wire.MountPointInfo
 
getShellName() - Method in class alluxio.cli.AbstractShell
 
getShowPermissions() - Method in class alluxio.wire.MasterWebUIBrowse
Gets show permissions.
getShowPermissions() - Method in class alluxio.wire.MasterWebUIData
Gets show permissions.
getSize() - Method in class alluxio.util.UnixMountInfo.Options
 
getSize() - Method in class alluxio.util.webui.UIFileInfo
Gets size.
getSize() - Method in class alluxio.worker.block.AllocateOptions
 
getSizeFromBytes(long) - Static method in class alluxio.util.FormatUtils
Returns a human-readable version of bytes 10GB 2048KB etc.
getSleeper() - Method in class alluxio.time.TimeContext
 
getSleepTime() - Method in class alluxio.retry.ExponentialBackoffRetry
 
getSleepTime() - Method in class alluxio.retry.SleepingRetry
How long to sleep before the next retry is performed.
getSleepUnit() - Method in class alluxio.retry.SleepingRetry
Unit of time that SleepingRetry.getSleepTime() is measured in.
getSnapshot() - Method in class alluxio.metrics.MaxReservoir
Returns a snapshot of the reservoir's values, which has the max value set as the overall max value sent as an update to this reservoir.
getSocketAddress() - Method in class alluxio.grpc.GrpcServerAddress
 
getSource() - Method in class alluxio.metrics.Metric
 
getSource() - Method in class alluxio.wire.Property
 
getSource(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
 
getSource(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
 
getSource(PropertyKey) - Static method in class alluxio.conf.Configuration
 
getSource(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getSource(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getSource(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getSpace(String, UnderFileSystem.SpaceType) - Method in interface alluxio.underfs.UnderFileSystem
Queries the under file system about the space of the indicated path (e.g., space left, space used and etc).
getSpace(String, UnderFileSystem.SpaceType) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getSrc() - Method in class alluxio.job.CopyJobRequest
 
getStart() - Method in class alluxio.wire.BlockReadRequest
 
getStartTime() - Method in class alluxio.util.webui.UIWorkerInfo
Gets start time.
getStartTime() - Method in class alluxio.wire.MasterWebUIOverview
Gets start time.
getStartTimeMs() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
getStartTimeMs() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
getStartTimeMs() - Method in class alluxio.wire.AlluxioMasterInfo
 
getStartTimeMs() - Method in class alluxio.wire.AlluxioProxyInfo
 
getStartTimeMs() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getStartTimeMs() - Method in class alluxio.wire.WorkerInfo
 
getState() - Method in class alluxio.cli.ValidationTaskResult
 
getState() - Method in class alluxio.util.webui.NodeInfo
Gets state.
getState() - Method in class alluxio.wire.BackupStatus
 
getState() - Method in class alluxio.wire.WorkerInfo
 
getStatus() - Method in exception alluxio.exception.runtime.AlluxioRuntimeException
 
getStatus() - Method in exception alluxio.exception.status.AlluxioStatusException
 
getStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
getStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Gets the file or directory status.
getStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getStatusCode() - Method in exception alluxio.exception.status.AlluxioStatusException
 
getStealCount() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns an estimate of the total number of tasks stolen from one thread's work queue by another.
getStorageDirs() - Method in class alluxio.wire.WorkerWebUIOverview
Gets storage dirs.
getStorageDirs() - Method in interface alluxio.worker.block.meta.StorageTier
 
getStorageTierAlias() - Method in class alluxio.util.webui.StorageTierInfo
Gets storage tier alias.
getStorageTierAssoc() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getStorageTierInfos() - Method in class alluxio.wire.MasterWebUIOverview
Gets storage tier infos.
getStoreMeta() - Method in interface alluxio.worker.block.BlockWorker
Gets the metadata for the entire block store.
getStoreMetaFull() - Method in interface alluxio.worker.block.BlockWorker
Similar as BlockWorker.getStoreMeta() except that this also contains full blockId list.
getString(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Gets the String value for the given key.
getString(PropertyKey) - Static method in class alluxio.conf.Configuration
Gets the String value for the given key.
getString(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
getString(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
getString(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
getSubCommands() - Method in interface alluxio.cli.Command
 
getSubject() - Method in class alluxio.ClientContext
 
getSubject() - Method in class alluxio.security.authorization.AclEntry
 
getSubject() - Method in class alluxio.security.user.BaseUserState
 
getSubject() - Method in interface alluxio.security.user.UserState
Returns the Subject for this user.
getSuperclassFieldPadding() - Method in interface alluxio.util.ObjectSizeCalculator.MemoryLayoutSpecification
Returns the quantum field size for a field owned by one of an object's ancestor superclasses in this JVM.
getSupportedVersions(String, AlluxioConfiguration) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Get a list of supported versions for a particular UFS path.
getSurplusQueuedTaskCount() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns an estimate of how many more locally queued tasks are held by the current worker thread than there are other worker threads that might steal them, or zero if this thread is not operating in a ForkJoinPool.
getSyncMetricName(long) - Static method in class alluxio.metrics.MetricKey
 
getSyncPoints() - Method in class alluxio.SyncInfo
Returns a list of sync points.
getSyncPointUri() - Method in class alluxio.wire.SyncPointInfo
Get the uri of the sync point.
getSyncStatus() - Method in class alluxio.wire.SyncPointInfo
Get the initial sync status.
getTable() - Method in class alluxio.client.hive.HiveCacheContext
 
getTag(Fingerprint.Tag) - Method in class alluxio.underfs.Fingerprint
 
getTags() - Method in class alluxio.metrics.Metric
 
getTagUfsValueFromFullName(String) - Static method in class alluxio.metrics.Metric
Gets value of ufs tag from the full metric name.
getTasks() - Method in interface alluxio.cli.ValidationTool
 
getTempBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
Gets the temp metadata of a specific block from local storage.
getTempBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
Gets the TempBlockMeta from this storage dir by its block id.
getTempBlockWriterRemote(long, long) - Method in interface alluxio.worker.block.BlockWorker
Opens a BlockWriter for an existing temporary block.
getThreadIdentifier(Thread) - Static method in class alluxio.util.ThreadUtils
 
getThreadName() - Method in class alluxio.heartbeat.ScheduledTimer
 
getThreadNames() - Static method in class alluxio.heartbeat.HeartbeatScheduler
 
getTier(int) - Method in class alluxio.wire.TieredIdentity
 
getTierAlias() - Method in class alluxio.util.webui.UIStorageDir
Gets tier alias.
getTierAlias() - Method in class alluxio.util.webui.UIUsageOnTier
Gets tier alias.
getTierAlias() - Method in class alluxio.wire.BlockLocation
 
getTierAlias() - Method in interface alluxio.worker.block.meta.StorageTier
 
getTierCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
 
getTierCapacity() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getTieredIdentity() - Method in class alluxio.wire.WorkerNetAddress
 
getTierName() - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
getTierOrdinal() - Method in interface alluxio.worker.block.meta.StorageTier
 
getTierPaths() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getTiers() - Method in class alluxio.wire.TieredIdentity
 
getTimedOutSessions() - Method in class alluxio.Sessions
Gets the sessions that timed out.
getTimeoutMs() - Method in class alluxio.network.netty.NettyRPCContext
 
getTimeoutMs() - Method in class alluxio.util.WaitForOptions
 
getTimerClass(String) - Static method in class alluxio.heartbeat.HeartbeatContext
 
getTimerClasses() - Static method in class alluxio.heartbeat.HeartbeatContext
 
getTimeSeriesMetrics() - Method in class alluxio.wire.MasterWebUIMetrics
 
getTimeStamp() - Method in class alluxio.metrics.TimeSeries.DataPoint
 
getTmpDir(List<String>) - Static method in class alluxio.util.CommonUtils
 
getTotal() - Method in class alluxio.wire.Capacity
 
getTotalAllocatedBytes() - Method in class alluxio.wire.JournalDiskInfo
 
getTotalBytesReadDomainSocket() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read from domain socket.
getTotalBytesReadDomainSocketThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read from domain socket throughput.
getTotalBytesReadLocal() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read local.
getTotalBytesReadLocalThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read local throughput.
getTotalBytesReadRemote() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read remote.
getTotalBytesReadRemoteThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read remote throughput.
getTotalBytesReadUfs() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read ufs.
getTotalBytesReadUfsThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes read ufs throughput.
getTotalBytesWrittenDomainSocket() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written through domain socket.
getTotalBytesWrittenDomainSocketThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written through domain socket throughput.
getTotalBytesWrittenLocal() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written local.
getTotalBytesWrittenLocalThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written local throughput.
getTotalBytesWrittenRemote() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written remote.
getTotalBytesWrittenRemoteThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written remote throughput.
getTotalBytesWrittenUfs() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written ufs.
getTotalBytesWrittenUfsThroughput() - Method in class alluxio.wire.MasterWebUIMetrics
Gets total bytes written ufs throughput.
getTotalExtraTime() - Method in class alluxio.util.JvmPauseMonitor
 
getTotalPath() - Method in class alluxio.wire.MasterWebUIOverview
Gets total path.
getTtl() - Method in class alluxio.client.file.URIStatus
 
getTtl() - Method in class alluxio.wire.FileInfo
 
getTtlAction() - Method in class alluxio.client.file.URIStatus
 
getTtlAction() - Method in class alluxio.wire.FileInfo
 
getTxId() - Method in class alluxio.SyncInfo
returns the transaction id that is synced in this sync period.
getType() - Method in interface alluxio.cli.ValidationToolFactory
 
getType() - Method in class alluxio.conf.PropertyKey
 
getType() - Method in class alluxio.conf.Source
 
getType() - Method in class alluxio.job.CopyJobRequest
 
getType() - Method in class alluxio.job.JobDescription
 
getType() - Method in interface alluxio.job.JobRequest
 
getType() - Method in class alluxio.job.LoadJobRequest
 
getType() - Method in class alluxio.network.protocol.RPCMessage
Returns the type of the message.
getType() - Method in class alluxio.network.protocol.RPCProtoMessage
 
getType() - Method in class alluxio.security.authorization.AclEntry
 
getUfsCapacity() - Method in class alluxio.wire.AlluxioMasterInfo
 
getUfsCapacityBytes() - Method in class alluxio.util.webui.UIMountPointInfo
Gets ufs capacity bytes.
getUfsCapacityBytes() - Method in class alluxio.wire.MountPointInfo
 
getUfsFingerprint() - Method in class alluxio.client.file.URIStatus
 
getUfsFingerprint() - Method in class alluxio.wire.FileInfo
 
getUfsLocations() - Method in class alluxio.wire.FileBlockInfo
 
getUfsMountPointUri() - Method in class alluxio.underfs.UfsManager.UfsClient
 
getUfsOps() - Method in class alluxio.wire.MasterWebUIMetrics
Gets ufs ops.
getUfsOpsSaved() - Method in class alluxio.wire.MasterWebUIMetrics
Gets ufs ops saved.
getUfsPath() - Method in class alluxio.client.file.URIStatus
 
getUfsPath() - Method in class alluxio.wire.FileInfo
 
getUfsReadSize() - Method in class alluxio.wire.MasterWebUIMetrics
Gets ufs read size.
getUfsType() - Method in class alluxio.util.webui.UIMountPointInfo
Gets ufs type.
getUfsType() - Method in class alluxio.wire.MountPointInfo
 
getUfsUri() - Method in class alluxio.util.webui.UIMountPointInfo
Gets ufs uri.
getUfsUri() - Method in class alluxio.wire.MountPointInfo
 
getUfsUsedBytes() - Method in class alluxio.util.webui.UIMountPointInfo
Gets ufs used bytes.
getUfsUsedBytes() - Method in class alluxio.wire.MountPointInfo
 
getUfsWriteSize() - Method in class alluxio.wire.MasterWebUIMetrics
Gets ufs write size.
getUMask(String) - Static method in class alluxio.util.ModeUtils
Gets the file / directory creation umask.
getUncaughtExceptionHandler() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns the handler for internal worker threads that terminate due to unrecoverable errors encountered while executing tasks.
getUnderFileSystem() - Method in class alluxio.underfs.UnderFileSystemWithLogging
This is only used in the test.
getUnderFSType() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
getUnderFSType() - Method in interface alluxio.underfs.UnderFileSystem
Returns the name of the under filesystem implementation.
getUnderFSType() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
getUnderStorageType() - Method in enum alluxio.client.WriteType
 
getUniqueBlockCount() - Method in class alluxio.wire.MasterWebUIOverview
Gets unique block count.
getUnixGroups(String) - Static method in class alluxio.util.CommonUtils
Gets the current user's group list from Unix by running the command 'groups' NOTE.
getUnixMountInfo() - Static method in class alluxio.util.ShellUtils
Gets system mount information.
getUptime() - Method in class alluxio.util.webui.UIWorkerInfo
Gets uptime.
getUptime() - Method in class alluxio.wire.MasterWebUIOverview
Gets uptime.
getUptimeClockTime() - Method in class alluxio.util.webui.NodeInfo
Gets uptime clock time.
getUptimeMs() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
getUptimeMs() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
getUptimeMs() - Method in class alluxio.wire.AlluxioMasterInfo
 
getUptimeMs() - Method in class alluxio.wire.AlluxioProxyInfo
 
getUptimeMs() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getUri() - Method in class alluxio.wire.UfsInfo
 
getUriValidationEnabled() - Method in class alluxio.ClientContext
 
getUsage() - Method in interface alluxio.cli.Command
 
getUsageCount() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
getUsageOnTiers() - Method in class alluxio.wire.WorkerWebUIOverview
Gets usage on tiers.
getUsed() - Method in class alluxio.wire.Capacity
 
getUsedBytes() - Method in class alluxio.util.webui.UIStorageDir
Gets used bytes.
getUsedBytes() - Method in class alluxio.util.webui.UIUsageOnTier
Gets used bytes.
getUsedBytes() - Method in class alluxio.wire.BlockMasterInfo
 
getUsedBytes() - Method in class alluxio.wire.JournalDiskInfo
 
getUsedBytes() - Method in class alluxio.wire.WorkerInfo
 
getUsedBytes() - Method in class alluxio.wire.WorkerWebUIOverview
Gets used bytes.
getUsedBytes() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getUsedBytesOnDirs() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getUsedBytesOnTiers() - Method in class alluxio.wire.BlockMasterInfo
 
getUsedBytesOnTiers() - Method in class alluxio.wire.WorkerInfo
 
getUsedBytesOnTiers() - Method in interface alluxio.worker.block.BlockStoreMeta
 
getUsedCapacity() - Method in class alluxio.util.webui.StorageTierInfo
Gets used capacity.
getUsedCapacity() - Method in class alluxio.wire.MasterWebUIOverview
Gets used capacity.
getUsedMemory() - Method in class alluxio.util.webui.NodeInfo
Gets used memory.
getUsedSpacePercent() - Method in class alluxio.util.webui.NodeInfo
Gets used space percent.
getUsedSpacePercent() - Method in class alluxio.util.webui.StorageTierInfo
Gets used space percent.
getUser() - Method in class alluxio.security.user.BaseUserState
 
getUser() - Method in interface alluxio.security.user.UserState
Returns the User object for this user.
getUserAgentString(String, List<String>) - Static method in class alluxio.check.UpdateCheck
 
getUserChannel(AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
Gets the ChannelType properly from the USER_NETWORK_NETTY_CHANNEL property key.
getUserInfoForChannel(UUID) - Method in interface alluxio.security.authentication.AuthenticationServer
 
getUserInfoForChannel(UUID) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
getUserState() - Method in class alluxio.ClientContext
 
getValue() - Method in enum alluxio.client.ReadType
 
getValue() - Method in enum alluxio.client.WriteType
 
getValue() - Method in class alluxio.conf.path.TrieNode
 
getValue() - Method in class alluxio.metrics.Metric
 
getValue() - Method in class alluxio.metrics.TimeSeries.DataPoint
 
getValue() - Method in enum alluxio.underfs.UnderFileSystem.SpaceType
 
getValue() - Method in class alluxio.util.executor.ControllableQueue.DelayNode
 
getValue() - Method in enum alluxio.wire.CommandType
 
getValue() - Method in enum alluxio.wire.LoadMetadataType
 
getValue() - Method in class alluxio.wire.Property
 
getValue() - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
getValue(String) - Method in class alluxio.metrics.aggregator.SingleTagValueAggregator
 
getValue(String) - Method in interface alluxio.metrics.MultiValueMetricsAggregator
Gets the metric value of the given fully qualified metric name.
getValue(Map<MetricsFilter, Set<Metric>>) - Method in interface alluxio.metrics.SingleValueAggregator
Gets the aggregated value from the filtered metrics.
getValueFromStaticMapping(String, String) - Static method in class alluxio.util.CommonUtils
Gets the value with a given key from a static key/value mapping in string format.
getValues() - Method in class alluxio.wire.InconsistentProperty
 
getVersion() - Method in interface alluxio.underfs.UnderFileSystemFactory
Get the version supported by this factory.
getVersion() - Method in class alluxio.util.webui.NodeInfo
Gets worker version.
getVersion() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
getVersion() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
getVersion() - Method in class alluxio.wire.AlluxioMasterInfo
 
getVersion() - Method in class alluxio.wire.AlluxioProxyInfo
 
getVersion() - Method in class alluxio.wire.AlluxioWorkerInfo
 
getVersion() - Method in class alluxio.wire.MasterWebUIOverview
Gets version.
getVersion() - Method in class alluxio.wire.WorkerInfo
 
getVersion() - Method in class alluxio.wire.WorkerWebUIOverview
Gets version.
getViewingOffset() - Method in class alluxio.wire.MasterWebUIBrowse
Gets viewing offset.
getViewingOffset() - Method in class alluxio.wire.MasterWebUILogs
Gets viewing offset.
getViewingOffset() - Method in class alluxio.wire.WorkerWebUILogs
Gets viewing offset.
getVolatileBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
Gets the metadata of a block given its block id or empty if block does not exist.
getWarnTimeExceeded() - Method in class alluxio.util.JvmPauseMonitor
 
getWebFileInfoEnabled() - Method in class alluxio.wire.MasterWebUIInit
Gets web file info enabled.
getWebFileInfoEnabled() - Method in class alluxio.wire.WorkerWebUIInit
Gets web file info enabled.
getWebPort() - Method in class alluxio.util.webui.NodeInfo
Gets web port.
getWebPort() - Method in class alluxio.wire.WorkerNetAddress
 
getWhitelist() - Method in class alluxio.wire.MasterWebUIConfiguration
Gets whitelist.
getWhitelist() - Method in class alluxio.wire.WorkerWebUIConfiguration
Gets whitelist.
getWhiteList() - Method in interface alluxio.worker.block.BlockWorker
 
getWorkerAddress() - Method in class alluxio.util.webui.UIWorkerInfo
Gets worker address.
getWorkerAddress() - Method in class alluxio.wire.BlockLocation
 
getWorkerCapacityFreePercentage() - Method in class alluxio.wire.WorkerWebUIMetrics
Gets worker capacity free percentage.
getWorkerCapacityUsedPercentage() - Method in class alluxio.wire.WorkerWebUIMetrics
Gets worker capacity used percentage.
getWorkerChannel(AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
Gets the worker channel properly from the WORKER_NETWORK_NETTY_CHANNEL property key.
getWorkerDataDirectory(String, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
 
getWorkerHostnames(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
Gets list of workers in conf directory.
getWorkerId() - Method in class alluxio.util.webui.NodeInfo
Gets worker id.
getWorkerId() - Method in class alluxio.wire.BlockLocation
 
getWorkerId() - Method in interface alluxio.worker.DataWorker
 
getWorkerInfo() - Method in class alluxio.wire.WorkerWebUIOverview
Gets worker info.
getWorkerPort() - Method in class alluxio.wire.MasterWebUIInit
Gets worker port.
getWorkers() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
getWorkers() - Method in class alluxio.wire.AlluxioMasterInfo
 
getXAttr() - Method in class alluxio.client.file.URIStatus
 
getXAttr() - Method in class alluxio.underfs.UfsStatus
Returns the extended attributes from the Ufs, if any.
getXAttr() - Method in class alluxio.wire.FileInfo
 
getZkAddress() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
getZone() - Method in class alluxio.clock.ElapsedTimeClock
 
getZone() - Method in class alluxio.clock.SystemClock
 
getZookeeperAddress() - Method in class alluxio.uri.ZookeeperAuthority
 
global() - Static method in class alluxio.conf.Configuration
 
GLOBAL - alluxio.client.quota.CacheScope.Level
 
GLOBAL - Static variable in class alluxio.client.quota.CacheScope
 
GraceMode - Enum in alluxio.master
Defines the grace mode of exclusive locking of the state-lock.
GraphiteSink - Class in alluxio.metrics.sink
A sink which publishes metric values to a Graphite server.
GraphiteSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.GraphiteSink
Creates a new GraphiteSink with a Properties and MetricRegistry.
GROUP - alluxio.underfs.Fingerprint.Tag
 
GROUP_COMPONENT - Static variable in enum alluxio.security.authorization.AclEntryType
 
GroupMappingService - Interface in alluxio.security.group
Interface for Alluxio user-to-groups mapping.
GroupMappingService.Factory - Class in alluxio.security.group
Factory for creating a new instance.
GrpcChannel - Class in alluxio.grpc
Used to gather gRPC level resources and indexes together.
GrpcChannel(GrpcChannelKey, ManagedChannel) - Constructor for class alluxio.grpc.GrpcChannel
Creates a new connection object.
GrpcChannelBuilder - Class in alluxio.grpc
A gRPC channel builder that authenticates with GrpcServer at the target during channel building.
GrpcChannelKey - Class in alluxio.grpc
Used to define a key for GrpcChannelPool.
GrpcChannelKey(GrpcNetworkGroup, GrpcServerAddress, int) - Constructor for class alluxio.grpc.GrpcChannelKey
Constructor.
GrpcChannelPool - Class in alluxio.grpc
Used to provide gRPC level connection management and pooling facilities.
GrpcExceptionUtils - Class in alluxio.grpc
Utility methods for conversion between alluxio and grpc status exceptions.
GrpcExceptionUtils() - Constructor for class alluxio.grpc.GrpcExceptionUtils
 
GrpcNetworkGroup - Enum in alluxio.grpc
Used to define connection level multiplexing groups.
GrpcSerializationUtils - Class in alluxio.grpc
Utilities for gRPC message serialization.
GrpcSerializationUtils() - Constructor for class alluxio.grpc.GrpcSerializationUtils
 
GrpcServer - Class in alluxio.grpc
An authenticated gRPC server.
GrpcServer(Server, AuthenticationServer, Closer, long) - Constructor for class alluxio.grpc.GrpcServer
Create a new instance of GrpcServer.
GrpcServerAddress - Class in alluxio.grpc
Defines an gRPC server endpoint.
GrpcServerBuilder - Class in alluxio.grpc
Provides authenticated gRPC server creation.
GrpcService - Class in alluxio.grpc
Utility class for wrapping gRPC service definition.
GrpcService(BindableService) - Constructor for class alluxio.grpc.GrpcService
Creates a new GrpcService.
GrpcService(ServerServiceDefinition) - Constructor for class alluxio.grpc.GrpcService
Creates a new GrpcService.
GrpcUtils - Class in alluxio.grpc
Utility methods for conversion between wire types and grpc types.

H

HADOOP_KERBEROS_KEYTAB_LOGIN_AUTORENEWAL - Static variable in class alluxio.conf.PropertyKey
 
HADOOP_KERBEROS_KEYTAB_LOGIN_AUTORENEWAL - Static variable in class alluxio.conf.PropertyKey.Name
 
HADOOP_KRB5_CONF_FILE - Static variable in class alluxio.conf.PropertyKey
 
HADOOP_KRB5_CONF_KEY_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
HADOOP_SECURITY_AUTHENTICATION - Static variable in class alluxio.conf.PropertyKey
 
HADOOP_SECURITY_AUTHENTICATION - Static variable in class alluxio.conf.PropertyKey.Name
 
HADOOP_VERSION - Static variable in class alluxio.ProjectConstants
 
handle(BiFunction<? super T, Throwable, ? extends U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
handle(BiFunction<? super T, Throwable, ? extends U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes either normally or exceptionally, is executed with this stage's result and exception as arguments to the supplied function.
handle(Callback[]) - Method in class alluxio.security.authentication.plain.PlainSaslClientCallbackHandler
 
handle(Callback[]) - Method in class alluxio.security.authentication.plain.PlainSaslServerCallbackHandler
 
handle(Callback[]) - Method in class alluxio.security.login.AppLoginModule.AppCallbackHandler
 
handleAsync(BiFunction<? super T, Throwable, ? extends U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
handleAsync(BiFunction<? super T, Throwable, ? extends U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes either normally or exceptionally, is executed using this stage's default asynchronous execution facility, with this stage's result and exception as arguments to the supplied function.
handleAsync(BiFunction<? super T, Throwable, ? extends U>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
handleAsync(BiFunction<? super T, Throwable, ? extends U>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes either normally or exceptionally, is executed using the supplied executor, with this stage's result and exception as arguments to the supplied function.
handleMessage(SaslMessage) - Method in class alluxio.security.authentication.AbstractSaslClientHandler
This is synchronized in order to protect AbstractSaslClientHandler.mSaslClient.
handleMessage(SaslMessage) - Method in class alluxio.security.authentication.AbstractSaslServerHandler
 
handleMessage(SaslMessage) - Method in interface alluxio.security.authentication.SaslClientHandler
Handles the given SaslMessage from the server.
handleMessage(SaslMessage) - Method in interface alluxio.security.authentication.SaslServerHandler
Handles given SaslMessage from the client.
hasAnnotation(PropertyKey) - Method in class alluxio.conf.DeprecatedKeyChecker
Returns whether or not the given property key is marked by this class' annotation.
hasAuthority() - Method in class alluxio.AlluxioURI
Tells if the AlluxioURI has authority or not.
hasBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
Checks if the storage has a given block.
hasBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
Checks if a block is in this storage dir.
hasExtended() - Method in class alluxio.security.authorization.AccessControlList
 
hasExtended() - Method in class alluxio.security.authorization.ExtendedACLEntries
 
hash() - Method in class alluxio.AlluxioURI
Computes the hash of this URI, with SHA-256, or MD5, or simple hashCode().
hash() - Method in interface alluxio.conf.AlluxioConfiguration
 
hash() - Method in class alluxio.conf.AlluxioProperties
 
hash() - Static method in class alluxio.conf.Configuration
 
hash() - Method in class alluxio.conf.InstancedConfiguration
 
hash(int, String) - Static method in class alluxio.util.URIUtils
Hashes a string for a URI hash.
Hash - Class in alluxio.conf
A hex encoded MD5 hash of the cluster or path configurations.
Hash(Supplier<Stream<byte[]>>) - Constructor for class alluxio.conf.Hash
 
hashCode() - Method in class alluxio.AlluxioURI
 
hashCode() - Method in class alluxio.client.file.CacheContext
 
hashCode() - Method in class alluxio.client.file.URIStatus
 
hashCode() - Method in class alluxio.client.hive.HiveCacheContext
 
hashCode() - Method in class alluxio.client.quota.CacheQuota
 
hashCode() - Method in class alluxio.client.quota.CacheScope
 
hashCode() - Method in class alluxio.collections.DelegatingSet
 
hashCode() - Method in class alluxio.collections.Pair
 
hashCode() - Method in class alluxio.collections.TwoKeyConcurrentMap
The hashCode implementation for this map simply uses the superclass's.
hashCode() - Method in class alluxio.conf.PropertyKey
 
hashCode() - Method in class alluxio.conf.Source
 
hashCode() - Method in class alluxio.grpc.GrpcChannel
 
hashCode() - Method in class alluxio.grpc.GrpcChannelKey
 
hashCode() - Method in class alluxio.grpc.GrpcServerAddress
 
hashCode() - Method in class alluxio.job.JobDescription
 
hashCode() - Method in interface alluxio.master.MasterInquireClient.ConnectDetails
 
hashCode() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
hashCode() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
hashCode() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
hashCode() - Method in class alluxio.metrics.Metric
 
hashCode() - Method in class alluxio.metrics.MetricKey
 
hashCode() - Method in class alluxio.metrics.MetricsFilter
 
hashCode() - Method in class alluxio.security.authorization.AccessControlList
 
hashCode() - Method in class alluxio.security.authorization.AclActions
 
hashCode() - Method in class alluxio.security.authorization.AclEntry
 
hashCode() - Method in class alluxio.security.authorization.DefaultAccessControlList
 
hashCode() - Method in class alluxio.security.authorization.ExtendedACLEntries
 
hashCode() - Method in class alluxio.security.authorization.Mode
 
hashCode() - Method in class alluxio.security.CurrentUser
 
hashCode() - Method in class alluxio.security.user.BaseUserState
 
hashCode() - Method in class alluxio.security.User
 
hashCode() - Method in class alluxio.SessionInfo
 
hashCode() - Method in class alluxio.underfs.options.CreateOptions
 
hashCode() - Method in class alluxio.underfs.options.DeleteOptions
 
hashCode() - Method in class alluxio.underfs.options.FileLocationOptions
 
hashCode() - Method in class alluxio.underfs.options.ListOptions
 
hashCode() - Method in class alluxio.underfs.options.MkdirsOptions
 
hashCode() - Method in class alluxio.underfs.options.OpenOptions
 
hashCode() - Method in class alluxio.underfs.UfsStatus
 
hashCode() - Method in class alluxio.uri.EmbeddedLogicalAuthority
 
hashCode() - Method in class alluxio.uri.MultiMasterAuthority
 
hashCode() - Method in class alluxio.uri.MultiPartSchemeURI
 
hashCode() - Method in class alluxio.uri.NoAuthority
 
hashCode() - Method in class alluxio.uri.SingleMasterAuthority
 
hashCode() - Method in class alluxio.uri.StandardURI
 
hashCode() - Method in class alluxio.uri.UnknownAuthority
 
hashCode() - Method in class alluxio.uri.ZookeeperAuthority
 
hashCode() - Method in class alluxio.uri.ZookeeperLogicalAuthority
 
hashCode() - Method in class alluxio.util.UnixMountInfo
 
hashCode() - Method in class alluxio.util.UnixMountInfo.Options
 
hashCode() - Method in class alluxio.util.WaitForOptions
 
hashCode() - Method in class alluxio.util.webui.NodeInfo
 
hashCode() - Method in class alluxio.wire.Address
 
hashCode() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
hashCode() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
hashCode() - Method in class alluxio.wire.AlluxioMasterInfo
 
hashCode() - Method in class alluxio.wire.AlluxioProxyInfo
 
hashCode() - Method in class alluxio.wire.AlluxioWorkerInfo
 
hashCode() - Method in class alluxio.wire.BlockInfo
 
hashCode() - Method in class alluxio.wire.BlockLocation
 
hashCode() - Method in class alluxio.wire.BlockMasterInfo
 
hashCode() - Method in class alluxio.wire.Capacity
 
hashCode() - Method in class alluxio.wire.ConfigHash
 
hashCode() - Method in class alluxio.wire.FileBlockInfo
 
hashCode() - Method in class alluxio.wire.FileInfo
 
hashCode() - Method in class alluxio.wire.InconsistentProperty
 
hashCode() - Method in class alluxio.wire.MasterInfo
 
hashCode() - Method in class alluxio.wire.MountPointInfo
 
hashCode() - Method in class alluxio.wire.TieredIdentity
 
hashCode() - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
hashCode() - Method in class alluxio.wire.WorkerInfo
 
hashCode() - Method in class alluxio.wire.WorkerNetAddress
 
hashCode() - Method in class alluxio.worker.block.AllocateOptions
 
hashCode() - Method in class alluxio.worker.block.BlockStoreLocation
 
hashCode() - Method in class alluxio.worker.block.CreateBlockOptions
 
hashIgnoreCase(int, String) - Static method in class alluxio.util.URIUtils
Hashes a string for a URI hash, while ignoring the case.
hasMount(long) - Method in interface alluxio.underfs.UfsManager
Checks if a mountId exists.
hasNext() - Method in class alluxio.resource.CloseableIterator
 
hasNoRestriction() - Method in class alluxio.worker.block.BlockStoreLocation
Check whether the location has no restriction, i.e., BlockStoreLocation.ANY_TIER_LOCATION.
hasPayload() - Method in class alluxio.network.protocol.RPCMessage
Returns true if the message has a payload.
hasPayload() - Method in class alluxio.network.protocol.RPCProtoMessage
 
hasPrefix(String, String) - Static method in class alluxio.util.io.PathUtils
Checks whether the given path contains the given prefix.
hasQueuedSubmissions() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if there are any tasks submitted to this pool that have not yet begun executing.
hasSameLock(LockResource) - Method in class alluxio.resource.LockResource
Returns true if the other LockResource contains the same lock.
hasScheme() - Method in class alluxio.AlluxioURI
Tells if this AlluxioURI has scheme or not.
hasSubCommand() - Method in interface alluxio.cli.Command
If a command has sub-commands, the first argument should be the sub-command's name, all arguments and options will be parsed for the sub-command.
hasTempBlockMeta(long) - Method in interface alluxio.worker.block.BlockStore
Checks if the storage has a given temp block.
hasTempBlockMeta(long) - Method in interface alluxio.worker.block.meta.StorageDir
Checks if a temp block is in this storage dir.
hasTerminal(String, boolean) - Method in class alluxio.conf.path.TrieNode
Checks whether the path has terminal nodes as parents or children.
hasWindowsDrive(String, boolean) - Static method in class alluxio.AlluxioURI
Checks if the path is a windows path.
HDFS_TOOL_TYPE - Static variable in class alluxio.cli.ValidationConfig
 
head(String, Integer) - Static method in class alluxio.util.network.HttpUtils
Uses the head method to send a url with arguments by http, this method can call RESTful Api.
HEADER - Static variable in class alluxio.Constants
 
HEADER_ABFS - Static variable in class alluxio.Constants
 
HEADER_ABFSS - Static variable in class alluxio.Constants
 
HEADER_ADL - Static variable in class alluxio.Constants
 
HEADER_ADLS - Static variable in class alluxio.Constants
 
HEADER_CEPHFS - Static variable in class alluxio.Constants
 
HEADER_CEPHFS_HADOOP - Static variable in class alluxio.Constants
 
HEADER_COS - Static variable in class alluxio.Constants
 
HEADER_COSN - Static variable in class alluxio.Constants
 
HEADER_GCS - Static variable in class alluxio.Constants
 
HEADER_HTTP - Static variable in class alluxio.Constants
 
HEADER_HTTPS - Static variable in class alluxio.Constants
 
HEADER_KODO - Static variable in class alluxio.Constants
 
HEADER_OBS - Static variable in class alluxio.Constants
 
HEADER_OSS - Static variable in class alluxio.Constants
 
HEADER_S3 - Static variable in class alluxio.Constants
 
HEADER_S3A - Static variable in class alluxio.Constants
 
HEADER_SWIFT - Static variable in class alluxio.Constants
 
HEADER_WASB - Static variable in class alluxio.Constants
 
HEADER_WASBS - Static variable in class alluxio.Constants
 
HealthCheckClient - Interface in alluxio
Client for checking service availability.
HEAP - alluxio.master.metastore.MetastoreType
 
heartbeat() - Method in interface alluxio.heartbeat.HeartbeatExecutor
Implements the heartbeat logic.
heartbeat() - Method in class alluxio.SessionInfo
Performs a session heartbeat.
HeartbeatContext - Class in alluxio.heartbeat
This is a static class for storing and retrieving heartbeat related information.
HeartbeatContext.HeartbeatType - Enum in alluxio.heartbeat
HeartBeat Enum Type.
HeartbeatExecutor - Interface in alluxio.heartbeat
An interface for a heartbeat execution.
HeartbeatScheduler - Class in alluxio.heartbeat
This class can be used for controlling heartbeat execution of a thread.
HeartbeatThread - Class in alluxio.heartbeat
Thread class to execute a heartbeat periodically.
HeartbeatThread(String, HeartbeatExecutor, long, AlluxioConfiguration, UserState) - Constructor for class alluxio.heartbeat.HeartbeatThread
HeartbeatThread(String, String, HeartbeatExecutor, long, AlluxioConfiguration, UserState) - Constructor for class alluxio.heartbeat.HeartbeatThread
Creates a Runnable to execute heartbeats for the given HeartbeatExecutor.
HeartbeatTimer - Interface in alluxio.heartbeat
An interface for heartbeat timers.
helpComplete(int) - Method in class alluxio.concurrent.jsr.CountedCompleter
If this task has not completed, attempts to process at most the given number of other unprocessed tasks for which this task is on the completion path, if any are known to exist.
helpQuiesce() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Possibly executes tasks until the pool hosting the current task is quiescent.
HFSUtils - Class in alluxio.util
Utility method called in alluxio-mount.sh to calculate space for Mac OS X HFS+.
HiveCacheContext - Class in alluxio.client.hive
Data structure that stores and returns Hive related Cache Scope.
HiveCacheContext(String, String, String) - Constructor for class alluxio.client.hive.HiveCacheContext
Constructor.
HMS_TOOL_TYPE - Static variable in class alluxio.cli.ValidationConfig
 
HOME - Static variable in class alluxio.conf.PropertyKey
 
HOME - Static variable in class alluxio.conf.PropertyKey.Name
 
HOUR - Static variable in class alluxio.Constants
 
HOUR_MS - Static variable in class alluxio.Constants
 
HttpUtils - Class in alluxio.util.network
Utility methods for working with http.
HttpUtils.IProcessInputStream - Interface in alluxio.util.network
This interface should be implemented by the http response body stream processor.

I

IBM_JAVA - Static variable in class alluxio.util.OSUtils
Indicates the current java vendor is IBM java or not.
IdentityUserGroupsMapping - Class in alluxio.security.group.provider
A simple implementation of GroupMappingService that returns a group which is same name with the given user name.
IdentityUserGroupsMapping() - Constructor for class alluxio.security.group.provider.IdentityUserGroupsMapping
Constructs a new IdentityUserGroupsMapping.
IdleWriteHandler - Class in alluxio.network.netty
Sends a keep-alive to the server whenever the channel has been idle for a period of time.
IdleWriteHandler() - Constructor for class alluxio.network.netty.IdleWriteHandler
Creates a new idle write handler.
IdUtils - Class in alluxio.util
Utility methods for working with an id in Alluxio.
IGNORE - alluxio.conf.PropertyKey.ConsistencyCheckLevel
Do not check consistency of property value.
IMPERSONATION_HDFS_USER - Static variable in class alluxio.Constants
 
IMPERSONATION_NONE - Static variable in class alluxio.Constants
 
ImpersonationAuthenticator - Class in alluxio.security.authentication
An authenticator for impersonation users.
ImpersonationAuthenticator(AlluxioConfiguration) - Constructor for class alluxio.security.authentication.ImpersonationAuthenticator
Constructs a new ImpersonationAuthenticator.
imply(Mode.Bits) - Method in enum alluxio.security.authorization.Mode.Bits
Checks whether these bits imply the given bits.
inc() - Method in class alluxio.concurrent.CountingLatch
Increases the counter.
INCOMPATIBLE_VERSION - alluxio.exception.ExceptionMessage
 
InconsistentProperty - Class in alluxio.wire
Records a property that is required or recommended to be consistent but is not within its scope.
InconsistentProperty() - Constructor for class alluxio.wire.InconsistentProperty
Creates a new instance of InconsistentProperty.
InconsistentProperty(InconsistentProperty) - Constructor for class alluxio.wire.InconsistentProperty
Creates a new instance of InconsistentProperty from proto representation.
increaseUsageCount() - Method in class alluxio.worker.block.io.LocalFileBlockReader
increase the file reader usage count.
incrementCounter(String, long) - Method in class alluxio.client.file.CacheContext
Increments the counter name by value.
incrementCounter(String, CacheContext.StatsUnit, long) - Method in class alluxio.client.file.CacheContext
Increments the counter name by value.
IndexDefinition<T,​V> - Class in alluxio.collections
A class representing an index for an IndexedSet.
IndexDefinition(boolean) - Constructor for class alluxio.collections.IndexDefinition
Constructs a new IndexDefinition instance.
IndexedSet<T> - Class in alluxio.collections
A set of objects that are indexed and thus can be queried by specific fields of the object.
IndexedSet(IndexDefinition<T, ?>, IndexDefinition<T, ?>...) - Constructor for class alluxio.collections.IndexedSet
Constructs a new IndexedSet instance with at least one field as the index.
indexOf(Object) - Method in class alluxio.collections.UnmodifiableArrayList
 
IndexType - Enum in alluxio.master.metastore.rocks
IndexType used in conjunction with BlockBasedTable.
info(String) - Method in class alluxio.util.logging.SamplingLogger
 
info(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
info(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
info(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
info(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
info(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
INFO_TIME_EXCEEDED - Static variable in class alluxio.metrics.MetricKey
 
INFO_TIME_EXCEEDED - Static variable in class alluxio.metrics.MetricKey.Name
 
inForkJoinPool() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns true if the current thread is a ForkJoinWorkerThread executing as a ForkJoinPool computation.
init(AlluxioConfiguration) - Method in class alluxio.util.network.tls.DefaultSslContextProvider
 
init(AlluxioConfiguration) - Method in interface alluxio.util.network.tls.SslContextProvider
Initializes provider.
initialize() - Method in interface alluxio.worker.block.BlockStore
Initialize the block store.
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class alluxio.security.login.AlluxioLoginModule
 
initialize(Subject, CallbackHandler, Map<String, ?>, Map<String, ?>) - Method in class alluxio.security.login.AppLoginModule
 
INITIALLY_SYNCED - alluxio.wire.SyncPointInfo.SyncStatus
 
initMultiPartUploadInternal() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
initShouldReportMetrics(MetricsSystem.InstanceType) - Static method in class alluxio.metrics.MetricsSystem
inList(String) - Method in class alluxio.collections.PrefixList
Checks whether a prefix of path is in the prefix list.
INODE_DOES_NOT_EXIST - alluxio.exception.ExceptionMessage
 
INODE_NOT_FOUND_PARTIAL_LISTING - alluxio.exception.ExceptionMessage
 
INODE_NOT_IN_PARTIAL_LISTING - alluxio.exception.ExceptionMessage
 
insert(Long) - Method in class alluxio.util.BucketCounter
insert a number to be counted.
insert(String) - Method in class alluxio.conf.path.TrieNode
Inserts a path into the trie.
instance() - Static method in class alluxio.resource.AlluxioResourceLeakDetectorFactory
 
INSTANCE - Static variable in class alluxio.grpc.GrpcChannelPool
 
INSTANCE - Static variable in class alluxio.time.ThreadSleeper
 
INSTANCE - Static variable in class alluxio.uri.NoAuthority
 
InstancedConfiguration - Class in alluxio.conf
Alluxio configuration.
InstancedConfiguration(AlluxioProperties) - Constructor for class alluxio.conf.InstancedConfiguration
Creates a new instance of InstancedConfiguration.
InstancedConfiguration(AlluxioProperties, boolean) - Constructor for class alluxio.conf.InstancedConfiguration
Creates a new instance of InstancedConfiguration.
instant() - Method in class alluxio.clock.ElapsedTimeClock
 
instant() - Method in class alluxio.clock.SystemClock
 
InstrumentedExecutorService - Class in alluxio.metrics
A wrapper around InstrumentedExecutorService that allows the metrics to be reset by MetricsSystem.resetAllMetrics().
InstrumentedExecutorService(ExecutorService, MetricRegistry, String) - Constructor for class alluxio.metrics.InstrumentedExecutorService
 
intAsUnsignedByteValue(int) - Static method in class alluxio.util.io.BufferUtils
Gets the unsigned byte value of an integer.
intBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
INTEGER - alluxio.conf.PropertyKey.PropertyType
The Property's value is of integer type, stored as an Integer.
intercept(ClientInterceptor) - Method in class alluxio.grpc.GrpcChannel
Registers interceptor to the channel.
intercept(ServerInterceptor) - Method in class alluxio.grpc.GrpcServerBuilder
Adds an interceptor for this server.
interceptCall(MethodDescriptor<ReqT, RespT>, CallOptions, Channel) - Method in class alluxio.security.authentication.ChannelIdInjector
 
interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class alluxio.security.authentication.AuthenticatedUserInjector
 
interceptCall(ServerCall<ReqT, RespT>, Metadata, ServerCallHandler<ReqT, RespT>) - Method in class alluxio.security.authentication.ClientIpAddressInjector
 
INTERNAL_SESSION_ID_BASE - Static variable in class alluxio.Sessions
 
InternalException - Exception in alluxio.exception.status
Exception representing an internal error.
InternalException(String) - Constructor for exception alluxio.exception.status.InternalException
 
InternalException(String, Throwable) - Constructor for exception alluxio.exception.status.InternalException
 
InternalException(Throwable) - Constructor for exception alluxio.exception.status.InternalException
 
InternalRuntimeException - Exception in alluxio.exception.runtime
Exception representing an internal error.
InternalRuntimeException(String) - Constructor for exception alluxio.exception.runtime.InternalRuntimeException
Constructor.
InternalRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.InternalRuntimeException
Constructor.
InternalRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.InternalRuntimeException
Constructor.
intersectionList() - Method in interface alluxio.StorageTierAssoc
 
intoByteArray(byte[]) - Static method in class alluxio.util.io.ChannelAdapters
Adapts a byte array to be the destination of a WritableByteChannel.
intoByteArray(byte[], int, int) - Static method in class alluxio.util.io.ChannelAdapters
Adapts a byte array to be the destination of a WritableByteChannel.
intoByteBuf(ByteBuf) - Static method in class alluxio.util.io.ChannelAdapters
todo(bowen): implement.
intoByteBuffer(ByteBuffer) - Static method in class alluxio.util.io.ChannelAdapters
Adapts a ByteBuffer to be the destination of a WritableByteChannel.
INVALID_ADDRESS_VALUE - alluxio.exception.ExceptionMessage
 
INVALID_ARG_TYPE - alluxio.exception.ExceptionMessage
 
INVALID_ARGS_NULL - alluxio.exception.ExceptionMessage
 
INVALID_ARGS_NUM - alluxio.exception.ExceptionMessage
 
INVALID_CONFIGURATION_KEY - alluxio.exception.ExceptionMessage
 
INVALID_CONFIGURATION_VALUE - alluxio.exception.ExceptionMessage
 
INVALID_CONTENT_HASH - Static variable in class alluxio.underfs.UfsFileStatus
 
INVALID_EXTENSION_NOT_JAR - alluxio.exception.ExceptionMessage
 
INVALID_FILE_ID - Static variable in class alluxio.util.IdUtils
 
INVALID_FINGERPRINT - Static variable in class alluxio.underfs.Fingerprint
 
INVALID_MODE - alluxio.exception.ExceptionMessage
 
INVALID_MODE - Static variable in class alluxio.Constants
 
INVALID_MODE_SEGMENT - alluxio.exception.ExceptionMessage
 
INVALID_MOUNT_ID - Static variable in class alluxio.util.IdUtils
 
INVALID_OPTION - alluxio.exception.ExceptionMessage
 
INVALID_OPTION_COUNT - alluxio.exception.ExceptionMessage
 
INVALID_OPTION_VALUE - alluxio.exception.ExceptionMessage
 
INVALID_TXID - Static variable in class alluxio.SyncInfo
 
INVALID_UFS_FINGERPRINT - Static variable in class alluxio.Constants
 
INVALID_WORKER_ID - Static variable in class alluxio.util.IdUtils
 
InvalidArgumentException - Exception in alluxio.exception.status
Exception indicating that a client specified an invalid argument.
InvalidArgumentException(String) - Constructor for exception alluxio.exception.status.InvalidArgumentException
 
InvalidArgumentException(String, Throwable) - Constructor for exception alluxio.exception.status.InvalidArgumentException
 
InvalidArgumentException(Throwable) - Constructor for exception alluxio.exception.status.InvalidArgumentException
 
InvalidArgumentRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that a client specified an invalid argument.
InvalidArgumentRuntimeException(String) - Constructor for exception alluxio.exception.runtime.InvalidArgumentRuntimeException
Constructor.
InvalidArgumentRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.InvalidArgumentRuntimeException
Constructor.
InvalidArgumentRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.InvalidArgumentRuntimeException
Constructor.
invalidateCachedFile(FileInfo) - Method in interface alluxio.worker.dora.DoraWorker
Invalidate all cached pages of this file.
InvalidFileSizeException - Exception in alluxio.exception
The exception thrown when the file of a size is invalid.
InvalidFileSizeException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.InvalidFileSizeException
Constructs a new exception with the specified exception message and multiple parameters.
InvalidFileSizeException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.InvalidFileSizeException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
InvalidFileSizeException(String) - Constructor for exception alluxio.exception.InvalidFileSizeException
Constructs a new exception with the specified detail message.
InvalidFileSizeException(String, Throwable) - Constructor for exception alluxio.exception.InvalidFileSizeException
Constructs a new exception with the specified detail message and cause.
InvalidPathException - Exception in alluxio.exception
The exception thrown when the path in Alluxio is invalid.
InvalidPathException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.InvalidPathException
Constructs a new exception with the specified exception message and multiple parameters.
InvalidPathException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.InvalidPathException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
InvalidPathException(String) - Constructor for exception alluxio.exception.InvalidPathException
Constructs a new exception with the specified detail message.
InvalidPathException(String, Throwable) - Constructor for exception alluxio.exception.InvalidPathException
Constructs a new exception with the specified detail message and cause.
InvalidWorkerStateException - Exception in alluxio.exception
The exception thrown when a worker is in an invalid state, i.e.
InvalidWorkerStateException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.InvalidWorkerStateException
Constructs a new exception with the specified exception message and multiple parameters.
InvalidWorkerStateException(String) - Constructor for exception alluxio.exception.InvalidWorkerStateException
Constructs a new exception with the specified detail message.
invoke() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Commences performing this task, awaits its completion if necessary, and returns its result, or throws an (unchecked) RuntimeException or Error if the underlying computation did so.
invoke(ForkJoinTask<T>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
Performs the given task, returning its result upon completion.
invokeAll(ForkJoinTask<?>...) - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Forks the given tasks, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
invokeAll(ForkJoinTask<?>, ForkJoinTask<?>) - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Forks the given tasks, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
invokeAll(Collection<? extends Callable<T>>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
invokeAll(Collection<? extends Callable<T>>) - Method in class alluxio.metrics.InstrumentedExecutorService
 
invokeAll(Collection<? extends Callable<T>>) - Method in class alluxio.util.executor.ControllableScheduler
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class alluxio.metrics.InstrumentedExecutorService
 
invokeAll(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
invokeAll(Collection<T>) - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Forks all tasks in the specified collection, returning when isDone holds for each task or an (unchecked) exception is encountered, in which case the exception is rethrown.
invokeAll(ExecutorService, List<Callable<T>>, long) - Static method in class alluxio.util.CommonUtils
Executes the given callables, waiting for them to complete (or time out).
invokeAll(List<Callable<T>>, long) - Static method in class alluxio.util.CommonUtils
Executes the given callables, waiting for them to complete (or time out).
invokeAny(Collection<? extends Callable<T>>) - Method in class alluxio.metrics.InstrumentedExecutorService
 
invokeAny(Collection<? extends Callable<T>>) - Method in class alluxio.util.executor.ControllableScheduler
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class alluxio.metrics.InstrumentedExecutorService
 
invokeAny(Collection<? extends Callable<T>>, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
IS_DIRECTORY - alluxio.metrics.MetricInfo.UfsOps
 
IS_FILE - alluxio.metrics.MetricInfo.UfsOps
 
is64Bit() - Static method in class alluxio.util.OSUtils
 
isAbsolute() - Method in class alluxio.AlluxioURI
Tells whether or not the AlluxioURI is absolute.
isAbsolute() - Method in class alluxio.uri.StandardURI
 
isAbsolute() - Method in interface alluxio.uri.URI
Tells whether or not the URI is absolute.
isAddressReachable(String, int, int) - Static method in class alluxio.util.CommonUtils
Validates whether a network address is reachable.
isAIX() - Static method in class alluxio.util.OSUtils
 
isAlluxioRunning(String) - Static method in class alluxio.util.ShellUtils
Checks whether an Alluxio service is running.
isAncestorOf(AlluxioURI) - Method in class alluxio.AlluxioURI
Returns true if the current AlluxioURI is an ancestor of another AlluxioURI.
isAnyDir() - Method in class alluxio.worker.block.BlockStoreLocation
Check whether the location is BlockStoreLocation.ANY_DIR.
isAnyDirWithTier() - Method in class alluxio.worker.block.BlockStoreLocation
Check whether the location is BlockStoreLocation.ANY_DIR within the specified tier.
isAnyMedium() - Method in class alluxio.worker.block.BlockStoreLocation
Check whether the location is BlockStoreLocation.ANY_MEDIUM.
isAnyTier() - Method in class alluxio.worker.block.BlockStoreLocation
Check whether the location is BlockStoreLocation.ANY_TIER.
isAsync() - Method in enum alluxio.client.WriteType
 
isAsyncCacheRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isAsyncPersist() - Method in enum alluxio.client.UnderStorageType
 
isAuthenticated() - Method in class alluxio.grpc.GrpcService
 
isAuthenticated() - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
 
isAuthenticationEnabled(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
Checks if authentication is enabled.
isAuthorizationEnabled(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
Checks if authorization is enabled.
isBackupDelegationEnabled() - Static method in class alluxio.util.FeatureUtils
Utility to check back delegation is enabled.
isBlockStoreRocks() - Static method in class alluxio.util.FeatureUtils
Utility to check the master block metastore is rocks.
isBuiltIn() - Method in class alluxio.conf.PropertyKey
 
isCache() - Method in enum alluxio.client.ReadType
 
isCache() - Method in enum alluxio.client.WriteType
 
isCacheable() - Method in class alluxio.client.file.URIStatus
 
isCacheable() - Method in class alluxio.wire.FileInfo
 
isCancelled() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns true if this CompletableFuture was cancelled before it completed normally.
isCancelled() - Method in class alluxio.concurrent.jsr.ForkJoinTask
 
isCephFS(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isCFT(String) - Static method in class alluxio.util.EnvironmentUtils
Checks whether the given user data belongs to an instance launched through CFT.
isClosed() - Method in class alluxio.AbstractClient
 
isClosed() - Method in interface alluxio.Client
 
isClosed() - Method in class alluxio.worker.block.io.BlockReader
 
isClosed() - Method in class alluxio.worker.block.io.DelegatingBlockReader
 
isClosed() - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
isClusterAggregated() - Method in class alluxio.metrics.MetricKey
 
isCollection(Object) - Static method in class alluxio.util.CommonUtils
 
isComplete() - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
isCompleted() - Method in class alluxio.client.file.URIStatus
 
isCompleted() - Method in class alluxio.wire.BackupStatus
 
isCompleted() - Method in class alluxio.wire.FileInfo
 
isCompletedAbnormally() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Returns true if this task threw an exception or was cancelled.
isCompletedExceptionally() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns true if this CompletableFuture completed exceptionally, in any way.
isCompletedNormally() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Returns true if this task completed without throwing an exception and was not cancelled.
isConnected() - Method in class alluxio.AbstractClient
 
isConnected() - Method in interface alluxio.Client
Returns the connected status of the client.
isDailyBackupEnabled() - Static method in class alluxio.util.FeatureUtils
Utility to check daily backup is enabled.
isDebugEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isDebugEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isDefault() - Method in class alluxio.security.authorization.AclEntry
 
isDeprecated(PropertyKey) - Static method in class alluxio.conf.PropertyKey
Returns whether or not the given property key is marked as deprecated.
isDeprecated(String) - Static method in class alluxio.conf.PropertyKey
 
isDirectory() - Method in class alluxio.underfs.UfsStatus
 
isDirectory(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
isDirectory(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
isDirectory(String) - Method in interface alluxio.underfs.UnderFileSystem
Checks if a directory exists in under file system.
isDirectory(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isDocker() - Static method in class alluxio.util.EnvironmentUtils
Utility to detect the docker deployment environment.
isDomainSocketAccessible(WorkerNetAddress, AlluxioConfiguration) - Static method in class alluxio.util.network.NettyUtils
 
isDomainSocketSupported(WorkerNetAddress) - Static method in class alluxio.util.network.NettyUtils
 
isDone() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns true if completed in any fashion: normally, exceptionally, or via cancellation.
isDone() - Method in class alluxio.concurrent.jsr.ForkJoinTask
 
isDynamic() - Method in class alluxio.conf.PropertyKey
 
isEC2() - Static method in class alluxio.util.EnvironmentUtils
Utility to detect the EC2 deployment environment.
isEmbeddedJournal() - Static method in class alluxio.util.FeatureUtils
Utility to check the master journal type is embedded journal.
isEmpty() - Method in class alluxio.collections.ConcurrentHashSet
 
isEmpty() - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
isEmpty() - Method in class alluxio.collections.DelegatingSet
 
isEmpty() - Method in class alluxio.collections.UnmodifiableArrayList
 
isEmpty() - Method in class alluxio.security.authorization.DefaultAccessControlList
Returns true if the default ACL is empty.
isEmpty() - Method in class alluxio.util.executor.ControllableQueue
 
isEMR(String) - Static method in class alluxio.util.EnvironmentUtils
Checks whether the given user data belongs to an instance launched through EMR.
isEnsureAtomic() - Method in class alluxio.underfs.options.CreateOptions
 
isErrorEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isErrorEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isEvictionAllowed() - Method in class alluxio.worker.block.AllocateOptions
 
isExistingDirectory(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
isExistingDirectory(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
isExistingDirectory(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
isExistingDirectory(String) - Method in interface alluxio.underfs.UnderFileSystem
Checks if a directory exists in under file system.
isExistingDirectory(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isFailed() - Method in class alluxio.wire.BackupStatus
 
isFatalError(Throwable) - Static method in class alluxio.util.CommonUtils
 
isFile() - Method in class alluxio.underfs.UfsStatus
 
isFile(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
isFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
isFile(String) - Method in interface alluxio.underfs.UnderFileSystem
Checks if a file exists in under file system.
isFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isFinished() - Method in class alluxio.wire.BackupStatus
 
isFolder() - Method in class alluxio.client.file.URIStatus
 
isFolder() - Method in class alluxio.wire.FileInfo
 
isForceLocation() - Method in class alluxio.worker.block.AllocateOptions
 
isForceSync() - Method in class alluxio.SyncInfo
returns true if this sync should happen on the entire directory.
isGcs(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isGoogleComputeEngine() - Static method in class alluxio.util.EnvironmentUtils
Utility to detect the Google compute engine deployment environment.
isHaMode(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
isHdfs(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isHdfsScheme(String) - Static method in class alluxio.cli.ValidationUtils
Checks if a path is HDFS.
isHealthy() - Method in class alluxio.grpc.GrpcChannel
 
isHealthy(Channel) - Method in class alluxio.network.netty.NettyChannelPool
Checks whether a channel is healthy.
isHealthy(T) - Method in class alluxio.resource.DynamicResourcePool
Checks whether a resource is healthy or not.
isHeartbeat() - Method in class alluxio.util.proto.ProtoMessage
 
isHidden() - Method in class alluxio.conf.PropertyKey
 
isIgnoredSiteProperty() - Method in class alluxio.conf.PropertyKey
 
isInfoEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isInfoEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isInodeStoreRocks() - Static method in class alluxio.util.FeatureUtils
Utility to check the master inode metastore is rocks.
isInterrupted(Throwable) - Static method in class alluxio.util.ExceptionUtils
 
isInTier(String) - Method in class alluxio.util.webui.UIFileBlockInfo
Is in tier boolean.
isKubernetes() - Static method in class alluxio.util.EnvironmentUtils
Utility to detect the k8s deployment environment.
isLinux() - Static method in class alluxio.util.OSUtils
 
isLocal(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isLocalAddress(String, int) - Static method in class alluxio.util.network.NetworkAddressUtils
 
isLocalBlockCloseRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockCompleteRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockCreateRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockCreateResponse() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockOpenRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalBlockOpenResponse() - Method in class alluxio.util.proto.ProtoMessage
 
isLocalFilesystem(String) - Static method in class alluxio.util.URIUtils
 
isLocalHost(WorkerNetAddress, AlluxioConfiguration) - Static method in class alluxio.util.CommonUtils
 
isMacOS() - Static method in class alluxio.util.OSUtils
 
isMasterAuditLoggingEnabled() - Static method in class alluxio.util.FeatureUtils
Utility to check master audit logging is enabled.
isMountingPoint(String, String[]) - Static method in class alluxio.util.ShellUtils
Checks whether a path is the mounting point of a RAM disk volume.
isMountPoint() - Method in class alluxio.client.file.URIStatus
 
isMountPoint() - Method in class alluxio.wire.FileInfo
 
isNested(String) - Method in class alluxio.conf.PropertyKey
 
isNettyEpollAvailable() - Static method in class alluxio.util.network.NettyUtils
 
isObjectStorage() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
isObjectStorage() - Method in class alluxio.underfs.BaseUnderFileSystem
 
isObjectStorage() - Method in class alluxio.underfs.ObjectUnderFileSystem
 
isObjectStorage() - Method in interface alluxio.underfs.UnderFileSystem
 
isObjectStorage() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isOpen() - Method in class alluxio.worker.block.io.BlockReadableChannel
 
isOss(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isPageStoreEnabled() - Static method in class alluxio.util.FeatureUtils
Utility to check page store is enabled.
isPathAbsolute() - Method in class alluxio.AlluxioURI
Tells whether or not the path component of the AlluxioURI is absolute.
isPersisted() - Method in class alluxio.client.file.URIStatus
 
isPersisted() - Method in class alluxio.wire.FileInfo
 
isPersistenceBlacklistEmpty() - Static method in class alluxio.util.FeatureUtils
Utility to check persistence black list is empty.
isPinned() - Method in class alluxio.client.file.URIStatus
 
isPinned() - Method in class alluxio.util.webui.UIFileInfo
Is pinned boolean.
isPinned() - Method in class alluxio.wire.FileInfo
 
isPositionShort() - Method in class alluxio.wire.BlockReadRequest
 
isPromote() - Method in enum alluxio.client.AlluxioStorageType
 
isPromote() - Method in enum alluxio.client.ReadType
 
isPromote() - Method in class alluxio.wire.BlockReadRequest
 
isQuiescent() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if all worker threads are currently idle.
isReadOnly() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
isReadOnly() - Method in class alluxio.util.webui.UIMountPointInfo
Is readonly.
isReadRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isReadResponse() - Method in class alluxio.util.proto.ProtoMessage
 
isRecursive() - Method in class alluxio.underfs.options.DeleteOptions
 
isRecursive() - Method in class alluxio.underfs.options.ListOptions
 
isReleasable() - Method in interface alluxio.concurrent.jsr.ForkJoinPool.ManagedBlocker
Returns true if blocking is unnecessary.
isRemoved(String) - Static method in class alluxio.conf.PropertyKey
Returns whether or not a property key has been removed from use.
isResponse() - Method in class alluxio.util.proto.ProtoMessage
 
isRetryable() - Method in exception alluxio.exception.runtime.AlluxioRuntimeException
 
isRoot() - Method in class alluxio.AlluxioURI
Tells whether or not the AlluxioURI is root.
isRoot(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Checks if the path is the root.
isRoot(String) - Static method in class alluxio.util.io.PathUtils
Checks if the given path is the root.
isRoot(T) - Method in class alluxio.collections.DirectedAcyclicGraph
Checks if a given payload is in a root of the DAG.
isS3(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isSecurityEnabled(AlluxioConfiguration) - Static method in class alluxio.util.SecurityUtils
Checks if security is enabled.
isSeekable() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
isSeekable() - Method in class alluxio.underfs.BaseUnderFileSystem
 
isSeekable() - Method in interface alluxio.underfs.UnderFileSystem
Denotes if the under storage supports seeking.
isSeekable() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
isServing() - Method in class alluxio.grpc.GrpcServer
 
isServing() - Method in interface alluxio.HealthCheckClient
 
isServing(String, int) - Static method in class alluxio.util.network.NetworkAddressUtils
 
isSet(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
Checks if the configuration contains a value for the given key.
isSet(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
Checks if there is a value set for the given key.
isSet(PropertyKey) - Static method in class alluxio.conf.Configuration
Checks if the configuration contains a value for the given key.
isSet(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
isSet(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
isSet(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
isSetByUser(PropertyKey) - Method in interface alluxio.conf.AlluxioConfiguration
 
isSetByUser(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
 
isSetByUser(PropertyKey) - Static method in class alluxio.conf.Configuration
Checks if the configuration contains a value for the given key that is set by a user.
isSetByUser(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
 
isSetByUser(PropertyKey) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
isSetByUser(PropertyKey) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
isShared() - Method in class alluxio.util.webui.UIMountPointInfo
Is shared.
isShutdown() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if this pool has been shut down.
isShutdown() - Method in class alluxio.grpc.GrpcChannel
 
isShutdown() - Method in class alluxio.metrics.InstrumentedExecutorService
 
isShutdown() - Method in class alluxio.util.executor.ControllableScheduler
 
isStarted() - Static method in class alluxio.metrics.MetricsSystem
 
isStarted() - Method in class alluxio.util.JvmPauseMonitor
 
isStorageDirAccessible(String) - Static method in class alluxio.util.io.FileUtils
Checks if a storage directory path is accessible.
isStore() - Method in enum alluxio.client.AlluxioStorageType
 
isSwift(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isSyncPersist() - Method in enum alluxio.client.UnderStorageType
 
isTemporary() - Method in class alluxio.client.file.CacheContext
 
isTemporaryFileName(String) - Static method in class alluxio.util.io.PathUtils
Determines whether the given path is a temporary file name generated by Alluxio.
isTerminated() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if all tasks have completed following shut down.
isTerminated() - Method in class alluxio.metrics.InstrumentedExecutorService
 
isTerminated() - Method in class alluxio.util.executor.ControllableScheduler
 
isTerminating() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns true if the process of termination has commenced but not yet completed.
isThrough() - Method in enum alluxio.client.WriteType
 
isTraceEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isTraceEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isTruncated() - Method in class alluxio.client.file.ListStatusPartialResult
 
isTruncatedMessageException(IOException) - Static method in class alluxio.util.proto.ProtoUtils
Checks whether the exception is an InvalidProtocolBufferException thrown because of a truncated message.
isUnique() - Method in class alluxio.collections.IndexDefinition
 
isUnsafeDirectPersistEnabled() - Static method in class alluxio.util.FeatureUtils
Utility to check unsafe direct persistence is enabled.
isValid() - Method in class alluxio.underfs.Fingerprint
Checks if the fingerprint object was generated from an INVALID_UFS_FINGERPRINT.
isValid() - Method in class alluxio.util.JvmPauseMonitor.GarbageCollectorMXBeanView
 
isValid(String) - Static method in class alluxio.conf.PropertyKey
 
isValid(String) - Static method in class alluxio.metrics.MetricKey
 
isWarnEnabled() - Method in class alluxio.util.logging.SamplingLogger
 
isWarnEnabled(Marker) - Method in class alluxio.util.logging.SamplingLogger
 
isWeb(UnderFileSystem) - Static method in class alluxio.util.UnderFileSystemUtils
 
isWindows() - Static method in class alluxio.util.OSUtils
 
isWriteRequest() - Method in class alluxio.util.proto.ProtoMessage
 
isZookeeperEnabled() - Static method in class alluxio.util.FeatureUtils
Utility to check Zookeeper is enabled.
iterator() - Method in class alluxio.collections.ConcurrentHashSet
 
iterator() - Method in class alluxio.collections.DelegatingSet
 
iterator() - Method in interface alluxio.collections.FieldIndex
Returns an iterator over the elements in this index.
iterator() - Method in class alluxio.collections.IndexedSet
Returns an iterator over the elements in this set.
iterator() - Method in class alluxio.collections.NonUniqueFieldIndex
 
iterator() - Method in class alluxio.collections.UniqueFieldIndex
 
iterator() - Method in class alluxio.collections.UnmodifiableArrayList
 
iterator() - Method in class alluxio.util.executor.UniqueBlockingQueue
 

J

JAVA_VENDOR_NAME - Static variable in class alluxio.util.OSUtils
The java vendor name used in this platform.
JmxSink - Class in alluxio.metrics.sink
A sink which listens for new metrics and exposes them as namespaces MBeans.
JmxSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.JmxSink
Creates a new JmxSink with a Properties and MetricRegistry.
JOB_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey
 
JOB_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_DEFAULT_MASTER_PORT - Static variable in class alluxio.Constants
 
JOB_DEFAULT_MASTER_WEB_PORT - Static variable in class alluxio.Constants
 
JOB_DEFAULT_WORKER_DATA_PORT - Static variable in class alluxio.Constants
 
JOB_DEFAULT_WORKER_PORT - Static variable in class alluxio.Constants
 
JOB_DEFAULT_WORKER_WEB_PORT - Static variable in class alluxio.Constants
 
JOB_DEFINITION_DOES_NOT_EXIST - alluxio.exception.ExceptionMessage
 
JOB_DOES_NOT_EXIST - alluxio.exception.ExceptionMessage
 
JOB_JOURNAL_NAME - Static variable in class alluxio.Constants
 
JOB_MASTER - alluxio.metrics.MetricsSystem.InstanceType
 
JOB_MASTER - alluxio.util.CommonUtils.ProcessType
 
JOB_MASTER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
JOB_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
JOB_MASTER_CLIENT_THREADS - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_CLIENT_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_EMBEDDED_JOURNAL_ADDRESSES - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_EMBEDDED_JOURNAL_ADDRESSES - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_EMBEDDED_JOURNAL_PORT - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_EMBEDDED_JOURNAL_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_FINISHED_JOB_PURGE_COUNT - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_FINISHED_JOB_PURGE_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_FINISHED_JOB_RETENTION_TIME - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_FINISHED_JOB_RETENTION_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_FULL_CAPACITY - alluxio.exception.ExceptionMessage
 
JOB_MASTER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_JOB_CAPACITY - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_JOB_CAPACITY - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_LOST_WORKER_DETECTION - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
JOB_MASTER_LOST_WORKER_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
JOB_MASTER_LOST_WORKER_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_LOST_WORKER_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_NAME - Static variable in class alluxio.Constants
 
JOB_MASTER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_NETWORK_PERMIT_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_NETWORK_PERMIT_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_RAFT - alluxio.util.network.NetworkAddressUtils.ServiceType
Job master Raft service (Netty).
JOB_MASTER_RPC - alluxio.util.network.NetworkAddressUtils.ServiceType
Job master RPC service (gRPC).
JOB_MASTER_RPC_ADDRESSES - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_RPC_ADDRESSES - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_WEB - alluxio.util.network.NetworkAddressUtils.ServiceType
Job master web service (Jetty).
JOB_MASTER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_WORKER_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_WORKER_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_MASTER_WORKER_SERVICE_NAME - Static variable in class alluxio.Constants
 
JOB_MASTER_WORKER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
JOB_MASTER_WORKER_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
JOB_MASTER_WORKER_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_REQUEST_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey
 
JOB_REQUEST_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_RETENTION_TIME - Static variable in class alluxio.conf.PropertyKey
 
JOB_RETENTION_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER - alluxio.metrics.MetricsSystem.InstanceType
 
JOB_WORKER - alluxio.util.CommonUtils.ProcessType
 
JOB_WORKER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_COMMAND_HANDLING - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
JOB_WORKER_COMMAND_HANDLING - Static variable in class alluxio.heartbeat.HeartbeatContext
 
JOB_WORKER_DATA_PORT - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_DATA_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_NAME - Static variable in class alluxio.Constants
 
JOB_WORKER_RPC - alluxio.util.network.NetworkAddressUtils.ServiceType
Job worker RPC service (gRPC).
JOB_WORKER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_THREADPOOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_THREADPOOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_THROTTLING - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_THROTTLING - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_WEB - alluxio.util.network.NetworkAddressUtils.ServiceType
Job master web service (Jetty).
JOB_WORKER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
JOB_WORKER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey
 
JOB_WORKER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
JobDescription - Class in alluxio.job
Job description that used as a key to identify the job in the scheduler.
JobDescription.Builder - Class in alluxio.job
Builder for JobDescription.
JobDoesNotExistException - Exception in alluxio.exception
The exception thrown when a job definition does not exist in Alluxio.
JobDoesNotExistException(long) - Constructor for exception alluxio.exception.JobDoesNotExistException
Constructs a new exception saying the specified job ID does not exist.
JobDoesNotExistException(String) - Constructor for exception alluxio.exception.JobDoesNotExistException
Constructs a new exception with the specified detail message.
jobMasterHostConfigured(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
JobRequest - Interface in alluxio.job
A job request that can be used to create Job.
join() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns the result value when complete, or throws an (unchecked) exception if completed exceptionally.
join() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Returns the result of the computation when it is done.
join(AlluxioURI) - Method in class alluxio.AlluxioURI
Append additional path elements to the end of an AlluxioURI.
join(String) - Method in class alluxio.AlluxioURI
Append additional path elements to the end of an AlluxioURI.
joinUnsafe(String) - Method in class alluxio.AlluxioURI
Append additional path elements to the end of an AlluxioURI.
JOURNAL_ENTRY_MISSING - alluxio.exception.ExceptionMessage
 
JOURNAL_FLUSH_FAILURE - alluxio.exception.ExceptionMessage
 
JOURNAL_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
JOURNAL_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
JOURNAL_MASTER_NAME - Static variable in class alluxio.Constants
 
JOURNAL_WRITE_AFTER_CLOSE - alluxio.exception.ExceptionMessage
 
JOURNAL_WRITE_FAILURE - alluxio.exception.ExceptionMessage
 
JournalClosedException - Exception in alluxio.exception
Exception thrown to indicate that an operation failed because the journal has been closed.
JournalClosedException(String) - Constructor for exception alluxio.exception.JournalClosedException
Constructs a JournalClosedException with the specified detail message.
JournalClosedException.IOJournalClosedException - Exception in alluxio.exception
Same as JournalClosedException, but extends IOException for situations where only IOException is allowed.
JournalDiskInfo - Class in alluxio.wire
A class representing the state of a physical device.
JournalDiskInfo(String, String, long, long, long, String) - Constructor for class alluxio.wire.JournalDiskInfo
Create a new instance of JournalDiskInfo representing the current utilization for a particular block device.
JournalType - Enum in alluxio.master.journal
Enumerates the different types of journals that Alluxio may be configured with.
JsonSerializable - Interface in alluxio.util
This represents stress test objects that can be ser/de to/from json.
jumpAndExecute(long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
Jumps to a future time by a given duration.
justification() - Method in annotation type alluxio.annotation.SuppressFBWarnings
 
JVM_MONITOR_INFO_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
JVM_MONITOR_INFO_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
JVM_MONITOR_SLEEP_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
JVM_MONITOR_SLEEP_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
JVM_MONITOR_WARN_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
JVM_MONITOR_WARN_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
JvmPauseMonitor - Class in alluxio.util
Class to monitor JVM with a daemon thread, the thread sleep period of time and get the true time the sleep takes.
JvmPauseMonitor(long, long, long) - Constructor for class alluxio.util.JvmPauseMonitor
Constructs JvmPauseMonitor.
JvmPauseMonitor.GarbageCollectorMXBeanView - Class in alluxio.util
An unmodifiable view of a garbage collector MX Bean.
JvmSource - Class in alluxio.metrics.source
A Source which collects JVM metrics, including JVM memory usage, GC counts, GC times, etc.
JvmSource() - Constructor for class alluxio.metrics.source.JvmSource
Creates a new JvmSource and register all JVM metrics.

K

KB - Static variable in class alluxio.Constants
 
kBinarySearch - alluxio.master.metastore.rocks.IndexType
 
kBinarySearchWithFirstKey - alluxio.master.metastore.rocks.IndexType
 
kDataBlockBinaryAndHash - alluxio.master.metastore.rocks.DataBlockIndexType
 
kDataBlockBinarySearch - alluxio.master.metastore.rocks.DataBlockIndexType
 
keepAliveTime(long, TimeUnit) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the server keep-alive time.
keepAliveTimeout(long, TimeUnit) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the server keep-alive timeout.
KERBEROS - alluxio.security.authentication.AuthType
User is aware in Alluxio.
KEY_CIRCULAR_DEPENDENCY - alluxio.exception.ExceptionMessage
 
KEY_NOT_BOOLEAN - alluxio.exception.ExceptionMessage
 
KEY_NOT_BYTES - alluxio.exception.ExceptionMessage
 
KEY_NOT_DOUBLE - alluxio.exception.ExceptionMessage
 
KEY_NOT_FLOAT - alluxio.exception.ExceptionMessage
 
KEY_NOT_INTEGER - alluxio.exception.ExceptionMessage
 
KEY_NOT_LONG - alluxio.exception.ExceptionMessage
 
KEY_NOT_MS - alluxio.exception.ExceptionMessage
 
keySet() - Method in class alluxio.collections.ConcurrentIdentityHashMap
Returns a set representing all keys contained within the map.
keySet() - Method in interface alluxio.conf.AlluxioConfiguration
 
keySet() - Method in class alluxio.conf.AlluxioProperties
 
keySet() - Static method in class alluxio.conf.Configuration
 
keySet() - Method in class alluxio.conf.InstancedConfiguration
 
keySet() - Method in class alluxio.conf.path.SpecificPathConfiguration
 
keySet() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
kHashSearch - alluxio.master.metastore.rocks.IndexType
 
KODO_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
 
KODO_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
KODO_DOWNLOAD_HOST - Static variable in class alluxio.conf.PropertyKey
 
KODO_DOWNLOAD_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
KODO_ENDPOINT - Static variable in class alluxio.conf.PropertyKey
 
KODO_ENDPOINT - Static variable in class alluxio.conf.PropertyKey.Name
 
KODO_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
 
KODO_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
kTwoLevelIndexSearch - alluxio.master.metastore.rocks.IndexType
 

L

LAST_TIER - Static variable in class alluxio.Constants
 
LastContactSecComparator() - Constructor for class alluxio.wire.WorkerInfo.LastContactSecComparator
LastContactSecComparator constructor.
lastIndexOf(Object) - Method in class alluxio.collections.UnmodifiableArrayList
 
LEAK_DETECTOR_EXIT_ON_LEAK - Static variable in class alluxio.conf.PropertyKey
 
LEAK_DETECTOR_EXIT_ON_LEAK - Static variable in class alluxio.conf.PropertyKey.Name
 
LEAK_DETECTOR_LEVEL - Static variable in class alluxio.conf.PropertyKey
 
LEAK_DETECTOR_LEVEL - Static variable in class alluxio.conf.PropertyKey.Name
 
length() - Method in class alluxio.conf.PropertyKey
 
level() - Method in class alluxio.client.quota.CacheScope
 
LINKED_BLOCKING_QUEUE - alluxio.executor.ThreadPoolExecutorQueueType
 
LINKED_BLOCKING_QUEUE_WITH_CAP - alluxio.executor.ThreadPoolExecutorQueueType
LinkedBlockingQueue.
LIST - alluxio.conf.PropertyKey.PropertyType
The Property's value is of list type, stored as a delimiter separated string.
LIST_STATUS - alluxio.metrics.MetricInfo.UfsOps
 
listBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
listExtensions(String) - Static method in class alluxio.util.ExtensionUtils
List extension jars from the configured extensions directory.
listInternal(String, ListOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
Lists the files in the given path, the paths will be their logical names and not contain the folder suffix.
listIterator() - Method in class alluxio.collections.UnmodifiableArrayList
 
listIterator(int) - Method in class alluxio.collections.UnmodifiableArrayList
 
ListOptions - Class in alluxio.underfs.options
Method options for listing a directory in UnderFileSystem.
listStatus(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
listStatus(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
listStatus(String) - Method in interface alluxio.underfs.UnderFileSystem
Returns an array of statuses of the files and directories in the directory denoted by this abstract pathname.
listStatus(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
listStatus(String, ListStatusPOptions) - Method in interface alluxio.worker.dora.DoraWorker
List status from Under File System.
listStatus(String, ListOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
listStatus(String, ListOptions) - Method in class alluxio.underfs.BaseUnderFileSystem
 
listStatus(String, ListOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
listStatus(String, ListOptions) - Method in interface alluxio.underfs.UnderFileSystem
Returns an array of statuses of the files and directories in the directory denoted by this abstract pathname, with options.
listStatus(String, ListOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
listStatuses(String, ListOptions) - Method in interface alluxio.underfs.UnderFileSystem
Returns an array of statuses of the files and directories in the directory denoted by this abstract pathname, with options.
ListStatusPartialResult - Class in alluxio.client.file
Contains information about the result of a partial listing.
listToString(List<T>) - Static method in class alluxio.util.CommonUtils
Converts a list of objects to a string.
LIVE_WORKER_NUM - alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 
load(List<Block>, UfsReadOptions) - Method in interface alluxio.worker.block.BlockStore
Load blocks into alluxio.
load(List<Block>, UfsReadOptions) - Method in interface alluxio.worker.block.BlockWorker
Load blocks into alluxio.
load(List<File>, UfsReadOptions) - Method in interface alluxio.worker.dora.DoraWorker
Loads files from UFS to Alluxio.
LOAD_SESSION_ID - Static variable in class alluxio.Sessions
 
loadClass(String, boolean) - Method in class alluxio.extensions.ExtensionsClassLoader
 
loadClusterDefaults(InetSocketAddress, Scope) - Static method in class alluxio.conf.Configuration
Loads cluster default values for workers from the meta master if it's not loaded yet.
loadCommands() - Method in class alluxio.cli.AbstractShell
Map structure: Command name => Command instance.
loadCommands(String, Class[], Object[]) - Static method in class alluxio.cli.CommandUtils
Get instances of all subclasses of Command in a sub-package called "command" the given package.
loadConf(InetSocketAddress, boolean, boolean) - Method in class alluxio.ClientContext
This method will load the cluster and path level configuration defaults and update the configuration in one RPC.
loadConfIfNotLoaded(InetSocketAddress) - Method in class alluxio.ClientContext
Loads configuration if not loaded from meta master yet.
loadConfiguration(InetSocketAddress, AlluxioConfiguration, boolean, boolean) - Static method in class alluxio.conf.Configuration
Loads configuration from meta master in one RPC.
LoadJobRequest - Class in alluxio.job
The request of loading files.
LoadJobRequest(String, LoadJobPOptions) - Constructor for class alluxio.job.LoadJobRequest
 
LoadMetadataType - Enum in alluxio.wire
Types for loading metadata.
LOCAL - alluxio.client.file.cache.store.PageStoreType
A simple store with pages on the local filesystem.
LocalFileBlockReader - Class in alluxio.worker.block.io
This class provides read access to a block data file locally stored in managed storage.
LocalFileBlockReader(String) - Constructor for class alluxio.worker.block.io.LocalFileBlockReader
Constructs a Block reader given the file path of the block.
LocalFileBlockWriter - Class in alluxio.worker.block.io
This class provides write access to a temp block data file locally stored in managed storage.
LocalFileBlockWriter(String) - Constructor for class alluxio.worker.block.io.LocalFileBlockWriter
Constructs a Block writer given the file path of the block.
LocalFileInfo(String, String, long, long, long, boolean) - Constructor for class alluxio.util.webui.UIFileInfo.LocalFileInfo
Creates a new instance of UIFileInfo.LocalFileInfo.
localIdentity(AlluxioConfiguration) - Static method in class alluxio.network.TieredIdentityFactory
 
LOCALITY_COMPARE_NODE_IP - Static variable in class alluxio.conf.PropertyKey
 
LOCALITY_COMPARE_NODE_IP - Static variable in class alluxio.conf.PropertyKey.Name
 
LOCALITY_NODE - Static variable in class alluxio.Constants
 
LOCALITY_ORDER - Static variable in class alluxio.conf.PropertyKey
 
LOCALITY_ORDER - Static variable in class alluxio.conf.PropertyKey.Name
 
LOCALITY_RACK - Static variable in class alluxio.Constants
 
LOCALITY_SCRIPT - Static variable in class alluxio.conf.PropertyKey
 
LOCALITY_SCRIPT - Static variable in class alluxio.conf.PropertyKey.Name
 
LOCALITY_TIER - alluxio.conf.PropertyKey.Template
 
LOCALITY_TIER_NODE - Static variable in class alluxio.conf.PropertyKey
 
LOCALITY_TIER_RACK - Static variable in class alluxio.conf.PropertyKey
 
LocalityTier(String, String) - Constructor for class alluxio.wire.TieredIdentity.LocalityTier
 
LOCK_ID_FOR_DIFFERENT_BLOCK - alluxio.exception.ExceptionMessage
 
LOCK_ID_FOR_DIFFERENT_SESSION - alluxio.exception.ExceptionMessage
 
LOCK_NOT_RELEASED - alluxio.exception.ExceptionMessage
 
LOCK_RECORD_NOT_FOUND_FOR_LOCK_ID - alluxio.exception.ExceptionMessage
 
lockBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Locks an existing block and guards subsequent reads on this block.
lockBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Obtains a read lock the block.
lockBlockNoException(long, long) - Method in interface alluxio.worker.block.BlockStore
Locks an existing block and guards subsequent reads on this block.
lockBlockNoException(long, long) - Method in interface alluxio.worker.block.BlockWorker
Obtains a read lock the block without throwing an exception.
LockMode - Enum in alluxio.concurrent
ReadWriteLock types.
LockPool<K> - Class in alluxio.collections
A resource pool specifically designed to contain locks and will NOT evict any entries that are in use.
LockPool(Function<? super K, ? extends ReentrantReadWriteLock>, int, int, int, int) - Constructor for class alluxio.collections.LockPool
Constructor for a lock pool.
LockResource - Class in alluxio.resource
A resource lock that makes it possible to acquire and release locks using the following idiom:
LockResource(Lock) - Constructor for class alluxio.resource.LockResource
Creates a new instance of LockResource using the given lock.
LockResource(Lock, boolean, boolean) - Constructor for class alluxio.resource.LockResource
Creates a new instance of LockResource using the given lock.
LockResource(Lock, boolean, boolean, Runnable) - Constructor for class alluxio.resource.LockResource
Creates a new instance of LockResource using the given lock.
LOG - Static variable in class alluxio.underfs.ObjectLowLevelOutputStream
 
LOG - Static variable in interface alluxio.uri.Authority
 
logAllThreads() - Static method in class alluxio.util.ThreadUtils
Logs a stack trace for all threads currently running in the JVM, similar to jstack.
LOGGER_TYPE - Static variable in class alluxio.conf.PropertyKey
 
LOGGER_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
LOGICAL_MASTER_AUTH - Static variable in interface alluxio.uri.Authority
 
LOGICAL_ZOOKEEPER_AUTH - Static variable in interface alluxio.uri.Authority
 
login() - Method in class alluxio.security.login.AlluxioLoginModule
Authenticates the user (first phase).
login() - Method in class alluxio.security.login.AppLoginModule
Retrieves the user name by querying the property of PropertyKey.SECURITY_LOGIN_USERNAME through AppLoginModule.AppCallbackHandler.
login() - Method in class alluxio.security.user.BaseUserState
 
login() - Method in class alluxio.security.user.NoopUserState
 
login() - Method in class alluxio.security.user.SimpleUserState
 
LogInfo - Class in alluxio.wire
Information about the LogInfo.
LogInfo() - Constructor for class alluxio.wire.LogInfo
Creates a new instance of LogInfo.
LoginModuleConfiguration - Class in alluxio.security.login
A JAAS configuration that defines the login modules, by which JAAS uses to login.
LoginModuleConfiguration() - Constructor for class alluxio.security.login.LoginModuleConfiguration
Constructs a new LoginModuleConfiguration.
LoginModuleConfigurationUtils - Class in alluxio.security.login
This class provides constants used in JAAS login.
logout() - Method in class alluxio.security.login.AlluxioLoginModule
Logs out the user.
logout() - Method in class alluxio.security.login.AppLoginModule
Logs out the user
LOGS_DIR - Static variable in class alluxio.conf.PropertyKey
 
LOGS_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
logThreadInfo(Logger, String, long) - Static method in class alluxio.util.ThreadUtils
Log the current thread stacks at INFO level.
LogUtils - Class in alluxio.util
Utility methods for working with log.
LONG - alluxio.conf.PropertyKey.PropertyType
The Property's value is of long integer type, stored as a long.
longBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
LOST - alluxio.master.file.meta.PersistenceState
 
LOST_WORKER_NUM - alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 

M

main(String[]) - Static method in class alluxio.util.HFSUtils
The main class to invoke the getNumSector.
makeTag(int, int) - Static method in class alluxio.grpc.GrpcSerializationUtils
Makes a gRPC tag for a field.
managedBlock(ForkJoinPool.ManagedBlocker) - Static method in class alluxio.concurrent.jsr.ForkJoinPool
Runs the given possibly blocking task.
ManagedBlockingUfsForwarder - Class in alluxio.concurrent
Forwarder for UnderFileSystem objects that works through with ForkJoinPool's managed blocking.
ManagedBlockingUfsForwarder(UnderFileSystem) - Constructor for class alluxio.concurrent.ManagedBlockingUfsForwarder
Creates ManagedBlockingUfsForwarder instance.
map(Function<T, R>, Collection<T>) - Static method in class alluxio.util.StreamUtils
 
MAPPED - alluxio.network.netty.FileTransferType
Uses a MappedByteBuffer to transfer data over the network.
markOutdated() - Method in class alluxio.conf.Hash
Called when the version needs to be updated.
mask(AclActions) - Method in class alluxio.security.authorization.AclActions
Mask the actions.
MASK - alluxio.security.authorization.AclEntryType
 
MASK_COMPONENT - Static variable in enum alluxio.security.authorization.AclEntryType
 
maskObjects(Logger, Object...) - Method in interface alluxio.conf.SensitiveConfigMask
Copy and mask objects' sensitive information.
MASTER - alluxio.metrics.MetricsSystem.InstanceType
 
MASTER - alluxio.util.CommonUtils.ProcessType
 
MASTER_ABSENT_CACHE_HITS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ABSENT_CACHE_MISSES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ABSENT_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ABSENT_PATH_CACHE_QUEUE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ACTIVE_UFS_SYNC - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_ACTIVE_UFS_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_ASYNC_PERSIST_CANCEL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ASYNC_PERSIST_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ASYNC_PERSIST_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ASYNC_PERSIST_FILE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ASYNC_PERSIST_SIZE_VALIDATION - Static variable in class alluxio.conf.PropertyKey
Master related properties.
MASTER_ASYNC_PERSIST_SIZE_VALIDATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_ASYNC_PERSIST_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_AUDIT_LOG_ENTRIES_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_AUDIT_LOGGING_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_AUDIT_LOGGING_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_AUDIT_LOGGING_QUEUE_CAPACITY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_AUDIT_LOGGING_QUEUE_CAPACITY - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_ABANDON_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_ABANDON_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_CONNECT_INTERVAL_MAX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_CONNECT_INTERVAL_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_CONNECT_INTERVAL_MIN - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_CONNECT_INTERVAL_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_DELEGATION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_DELEGATION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_DIRECTORY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_DIRECTORY - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_ENTRY_BUFFER_COUNT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_ENTRY_BUFFER_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_STATE_LOCK_EXCLUSIVE_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_STATE_LOCK_EXCLUSIVE_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_STATE_LOCK_FORCED_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_STATE_LOCK_FORCED_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_STATE_LOCK_INTERRUPT_CYCLE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_STATE_LOCK_INTERRUPT_CYCLE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_STATE_LOCK_INTERRUPT_CYCLE_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_STATE_LOCK_INTERRUPT_CYCLE_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_SUSPEND_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_SUSPEND_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BACKUP_TRANSPORT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BACKUP_TRANSPORT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_BLOCK_HEAP_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_BLOCK_INTEGRITY_CHECK - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_BLOCK_INTEGRITY_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_BLOCK_METASTORE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BLOCK_SCAN_INVALID_BATCH_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_BLOCK_SCAN_INVALID_BATCH_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_CALL_HOME - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_CHECKPOINT_SCHEDULING - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_CHECKPOINT_SCHEDULING - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_CLUSTER_METRICS_UPDATE_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_CLUSTER_METRICS_UPDATE_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_CLUSTER_METRICS_UPDATER - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_CLUSTER_METRICS_UPDATER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_COLUMN_FILE_PREFIX - Static variable in class alluxio.Constants
 
MASTER_COMMAND_SESSION_ID - Static variable in class alluxio.Sessions
 
MASTER_COMPLETE_FILE_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_COMPLETED_OPERATION_RETRY_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_CONTAINER_ID_RESERVATION_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_CONTAINER_ID_RESERVATION_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_CREATE_DIRECTORIES_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_CREATE_FILES_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_DAILY_BACKUP - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_DAILY_BACKUP - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_DAILY_BACKUP_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DAILY_BACKUP_FILES_RETAINED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_FILES_RETAINED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DAILY_BACKUP_STATE_LOCK_GRACE_MODE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_STATE_LOCK_GRACE_MODE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DAILY_BACKUP_STATE_LOCK_SLEEP_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_STATE_LOCK_SLEEP_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DAILY_BACKUP_STATE_LOCK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_STATE_LOCK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DAILY_BACKUP_STATE_LOCK_TRY_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_STATE_LOCK_TRY_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DAILY_BACKUP_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_DAILY_BACKUP_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_DELETE_PATHS_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_DIAGNOSTIC - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_DIRECTORIES_CREATED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EDGE_CACHE_EVICTIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EDGE_CACHE_HITS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EDGE_CACHE_LOAD_TIMES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EDGE_CACHE_MISSES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EDGE_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EDGE_LOCK_POOL_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_ADDRESSES - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_ADDRESSES - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_CATCHUP_RETRY_WAIT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_CATCHUP_RETRY_WAIT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_ENTRY_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_ENTRY_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_FLUSH_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_FLUSH_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_MAX_ELECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_MAX_ELECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_MIN_ELECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_MIN_ELECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_PORT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_PROXY_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_RAFT_CLIENT_REQUEST_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_RAFT_CLIENT_REQUEST_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_RAFT_CLIENT_REQUEST_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_RAFT_CLIENT_REQUEST_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_RATIS_CONFIG - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_RATIS_CONFIG - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_RATIS_CONFIG_PROPERTY - alluxio.conf.PropertyKey.Template
 
MASTER_EMBEDDED_JOURNAL_RETRY_CACHE_EXPIRY_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_RETRY_CACHE_EXPIRY_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_DOWNLOAD_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_GENERATE_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_INSTALL_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_LAST_INDEX - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_REPLAY_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_REPLICATION_CHUNK_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_SNAPSHOT_REPLICATION_CHUNK_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_TRANSPORT_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_TRANSPORT_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_TRANSPORT_REQUEST_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_TRANSPORT_REQUEST_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_UNSAFE_FLUSH_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_UNSAFE_FLUSH_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_WRITE_LOCAL_FIRST_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_WRITE_REMOTE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_WRITE_REMOTE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_EMBEDDED_JOURNAL_WRITE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_EMBEDDED_JOURNAL_WRITE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_ACCESS_TIME_JOURNAL_FLUSH_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_ACCESS_TIME_JOURNAL_FLUSH_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_ACCESS_TIME_UPDATE_PRECISION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_ACCESS_TIME_UPDATE_PRECISION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_ACCESS_TIME_UPDATER_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_ACCESS_TIME_UPDATER_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_BLOCK_INFOS_GOT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILE_INFOS_GOT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILE_RECOMPUTATION - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_FILE_RECOMPUTATION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_FILE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILE_SYSTEM_LISTSTATUS_RESULTS_PER_MESSAGE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_SYSTEM_LISTSTATUS_RESULTS_PER_MESSAGE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_SYSTEM_MERGE_INODE_JOURNALS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_SYSTEM_MERGE_INODE_JOURNALS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_SYSTEM_OPERATION_RETRY_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_SYSTEM_OPERATION_RETRY_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILE_SYSTEM_OPERATION_RETRY_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FILE_SYSTEM_OPERATION_RETRY_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FILES_COMPLETED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_CREATED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_FREED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_PERSISTED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_PINNED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FILES_TO_PERSIST - Static variable in class alluxio.metrics.MetricKey
 
MASTER_FORMAT_FILE_PREFIX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_FORMAT_FILE_PREFIX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_FREE_FILE_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_GET_FILE_BLOCK_INFO_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_GET_FILE_INFO_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_GET_NEW_BLOCK_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_HEARTBEAT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_HEARTBEAT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_IMPERSONATION_GROUPS_OPTION - alluxio.conf.PropertyKey.Template
 
MASTER_IMPERSONATION_USERS_OPTION - alluxio.conf.PropertyKey.Template
 
MASTER_IN_SAFEMODE - alluxio.exception.ExceptionMessage
 
MASTER_INODE_CACHE_EVICTIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_CACHE_HIT_RATIO - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_CACHE_HITS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_CACHE_LOAD_TIMES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_CACHE_MISSES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_HEAP_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_LOCK_POOL_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_INODE_METASTORE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOB_CANCELED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COMPLETED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_FAIL_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_RATE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COPY_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_CREATED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_DISTRIBUTED_LOAD_CANCEL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_DISTRIBUTED_LOAD_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_DISTRIBUTED_LOAD_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_DISTRIBUTED_LOAD_FILE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_DISTRIBUTED_LOAD_RATE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_DISTRIBUTED_LOAD_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_FAILED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_BLOCK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_BLOCK_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_BLOCK_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_FILE_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_FILE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_RATE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_LOAD_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_RUNNING - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOB_SCHEDULER_RUNNING_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_BACKUP_WHEN_CORRUPTED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_BACKUP_WHEN_CORRUPTED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_CATCHUP_PROTECT_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_CATCHUP_PROTECT_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_CHECKPOINT_PERIOD_ENTRIES - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_CHECKPOINT_PERIOD_ENTRIES - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_CHECKPOINT_WARN - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_ENTRIES_SINCE_CHECKPOINT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_EXIT_ON_DEMOTION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_EXIT_ON_DEMOTION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_FLUSH_BATCH_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_FLUSH_BATCH_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_FLUSH_FAILURE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_FLUSH_RETRY_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_FLUSH_RETRY_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_FLUSH_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_FLUSH_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_FLUSH_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_FOLDER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_FOLDER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_GAIN_PRIMACY_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_GC_PERIOD_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_GC_PERIOD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_INIT_FROM_BACKUP - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_INIT_FROM_BACKUP - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_LAST_APPLIED_COMMIT_INDEX - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_LAST_CHECKPOINT_TIME - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_LOCAL_LOG_COMPACTION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_LOCAL_LOG_COMPACTION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_LOG_CONCURRENCY_MAX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_LOG_CONCURRENCY_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_LOG_SIZE_BYTES_MAX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_LOG_SIZE_BYTES_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_REQUEST_DATA_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_REQUEST_DATA_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_REQUEST_INFO_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_REQUEST_INFO_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_SEQUENCE_NUMBER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_SPACE_FREE_BYTES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_SPACE_FREE_PERCENT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_JOURNAL_SPACE_MONITOR - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_JOURNAL_SPACE_MONITOR - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_JOURNAL_SPACE_MONITOR_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_SPACE_MONITOR_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_SPACE_MONITOR_PERCENT_FREE_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_SPACE_MONITOR_PERCENT_FREE_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_SYNC_ROOT_AFTER_INIT_FROM_BACKUP - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_SYNC_ROOT_AFTER_INIT_FROM_BACKUP - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_TAILER_SHUTDOWN_QUIET_WAIT_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_TAILER_SHUTDOWN_QUIET_WAIT_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_TAILER_SLEEP_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_TAILER_SLEEP_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_TEMPORARY_FILE_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_TEMPORARY_FILE_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_TOLERATE_CORRUPTION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_TOLERATE_CORRUPTION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_TYPE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_JOURNAL_UFS_OPTION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JOURNAL_UFS_OPTION_PROPERTY - alluxio.conf.PropertyKey.Template
 
MASTER_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_KEYTAB_KEY_FILE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_KEYTAB_KEY_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LAST_BACKUP_ENTRIES_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LAST_BACKUP_RESTORE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LAST_BACKUP_RESTORE_TIME_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LAST_BACKUP_TIME_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LICENSE_CHECK - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_LISTING_CACHE_EVICTIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LISTING_CACHE_HITS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LISTING_CACHE_LOAD_TIMES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LISTING_CACHE_MISSES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LISTING_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LOCK_POOL_CONCURRENCY_LEVEL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOCK_POOL_CONCURRENCY_LEVEL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOCK_POOL_HIGH_WATERMARK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOCK_POOL_HIGH_WATERMARK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOCK_POOL_INITSIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOCK_POOL_INITSIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOCK_POOL_LOW_WATERMARK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOCK_POOL_LOW_WATERMARK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOG_CONFIG_REPORT_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOG_CONFIG_REPORT_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOG_CONFIG_REPORT_SCHEDULING - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_LOG_CONFIG_REPORT_SCHEDULING - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOGICAL_NAMESERVICES - alluxio.conf.PropertyKey.Template
 
MASTER_LOGICAL_RPC_ADDRESS - alluxio.conf.PropertyKey.Template
 
MASTER_LOGICAL_ZOOKEEPER_ADDRESS - alluxio.conf.PropertyKey.Template
 
MASTER_LOGICAL_ZOOKEEPER_NAMESERVICES - alluxio.conf.PropertyKey.Template
 
MASTER_LOST_BLOCK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LOST_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_LOST_FILES_DETECTION - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_LOST_FILES_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_MASTER_DETECTION - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_LOST_MASTER_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_WORKER_DELETION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOST_WORKER_DELETION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOST_WORKER_DETECTION - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_LOST_WORKER_DETECTION - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_LOST_WORKER_DETECTION_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOST_WORKER_DETECTION_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_LOST_WORKER_FILE_DETECTION_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_LOST_WORKER_FILE_DETECTION_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_MERGE_JOURNAL_CONTEXT_NUM_ENTRIES_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MERGE_JOURNAL_CONTEXT_NUM_ENTRIES_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_CONCURRENT_SYNC_DEDUP - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_CONCURRENT_SYNC_DEDUP - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_ACTIVE_PATHS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_CONCURRENCY_LEVEL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_CONCURRENCY_LEVEL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_EXECUTOR - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_EXECUTOR_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_EXECUTOR_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_EXECUTOR_QUEUE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_IGNORE_TTL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_IGNORE_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_INSTRUMENT_EXECUTOR - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_INSTRUMENT_EXECUTOR - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_LOCK_POOL_CONCURRENCY_LEVEL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_LOCK_POOL_CONCURRENCY_LEVEL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_LOCK_POOL_HIGH_WATERMARK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_LOCK_POOL_HIGH_WATERMARK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_LOCK_POOL_INITSIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_LOCK_POOL_INITSIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_LOCK_POOL_LOW_WATERMARK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_LOCK_POOL_LOW_WATERMARK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_NO_CHANGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_OPS_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PATHS_CANCEL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PATHS_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PATHS_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PENDING_PATHS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_CANCEL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_EXECUTOR - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_EXECUTOR_QUEUE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_OPS_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_PATHS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_RETRIES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_PREFETCH_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_REPORT_FAILURE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_REPORT_FAILURE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_SKIPPED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_TIME_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_TRAVERSAL_ORDER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_TRAVERSAL_ORDER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_UFS_MOUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_METADATA_SYNC_UFS_PREFETCH_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_UFS_PREFETCH_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_UFS_PREFETCH_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_UFS_PREFETCH_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METADATA_SYNC_UFS_PREFETCH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METADATA_SYNC_UFS_PREFETCH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_BLOCK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_DIR - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_DIR_BLOCK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_DIR_BLOCK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_DIR_INODE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_DIR_INODE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_CACHE_EVICT_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_CACHE_EVICT_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_CACHE_HIGH_WATER_MARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_CACHE_HIGH_WATER_MARK_RATIO - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_CACHE_LOW_WATER_MARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_CACHE_LOW_WATER_MARK_RATIO - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_CACHE_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_CACHE_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_ENUMERATOR_BUFFER_COUNT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_ENUMERATOR_BUFFER_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_INHERIT_OWNER_AND_GROUP - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_INHERIT_OWNER_AND_GROUP - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_INODE_ITERATION_CRAWLER_COUNT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_INODE_ITERATION_CRAWLER_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ITERATOR_READAHEAD_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ITERATOR_READAHEAD_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_METRICS_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_METRICS_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_LOCATION_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_META_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_META_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_META_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_META_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_META_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_META_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_BLOCK_META_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_BLOCK_META_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_EDGE_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_EDGE_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_EDGE_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_EDGE_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_EDGE_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_EDGE_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_EDGE_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_EDGE_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_INODE_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_INODE_BLOCK_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_INODE_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_INODE_BLOOM_FILTER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_INODE_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_INODE_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_INODE_INDEX - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_INODE_INDEX - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_PARALLEL_BACKUP - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_PARALLEL_BACKUP - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_PARALLEL_BACKUP_COMPRESSION_LEVEL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_PARALLEL_BACKUP_COMPRESSION_LEVEL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METASTORE_ROCKS_PARALLEL_BACKUP_THREADS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METASTORE_ROCKS_PARALLEL_BACKUP_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METRICS_FILE_SIZE_DISTRIBUTION_BUCKETS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METRICS_FILE_SIZE_DISTRIBUTION_BUCKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METRICS_HEAP_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METRICS_HEAP_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METRICS_SERVICE_THREADS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METRICS_SERVICE_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_METRICS_SYNC - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_METRICS_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_METRICS_TIME_SERIES - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_METRICS_TIME_SERIES - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_METRICS_TIME_SERIES_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_METRICS_TIME_SERIES_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_MIGRATE_JOB_CANCEL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MIGRATE_JOB_FAIL - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MIGRATE_JOB_FILE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MIGRATE_JOB_FILE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MIGRATE_JOB_SUCCESS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MOUNT_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_MOUNT_TABLE_ALLUXIO - alluxio.conf.PropertyKey.Template
 
MASTER_MOUNT_TABLE_OPTION - alluxio.conf.PropertyKey.Template
 
MASTER_MOUNT_TABLE_OPTION_PROPERTY - alluxio.conf.PropertyKey.Template
 
MASTER_MOUNT_TABLE_READONLY - alluxio.conf.PropertyKey.Template
 
MASTER_MOUNT_TABLE_ROOT_ALLUXIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_OPTION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_READONLY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_SHARED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MOUNT_TABLE_ROOT_UFS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_MOUNT_TABLE_SHARED - alluxio.conf.PropertyKey.Template
 
MASTER_MOUNT_TABLE_UFS - alluxio.conf.PropertyKey.Template
 
MASTER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
MASTER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_NETWORK_PERMIT_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_NETWORK_PERMIT_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_NEW_BLOCKS_GOT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ORPHANED_METRICS_CLEANER - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_ORPHANED_METRICS_CLEANER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_PATHS_DELETED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_PATHS_MOUNTED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_PATHS_RENAMED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_PATHS_UNMOUNTED - Static variable in class alluxio.metrics.MetricKey
 
MASTER_PERIODIC_BLOCK_INTEGRITY_CHECK_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERIODIC_BLOCK_INTEGRITY_CHECK_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERIODIC_BLOCK_INTEGRITY_CHECK_REPAIR - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERIODIC_BLOCK_INTEGRITY_CHECK_REPAIR - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_BLACKLIST - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_BLACKLIST - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_CHECKER - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_PERSISTENCE_CHECKER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_PERSISTENCE_CHECKER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_CHECKER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_INITIAL_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_INITIAL_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_MAX_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_MAX_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_MAX_TOTAL_WAIT_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_MAX_TOTAL_WAIT_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_PERSISTENCE_SCHEDULER - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_PERSISTENCE_SCHEDULER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_PERSISTENCE_SCHEDULER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PERSISTENCE_SCHEDULER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_POLICY_ACTION_SCHEDULER - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_PRINCIPAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_PRINCIPAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RAFT - alluxio.util.network.NetworkAddressUtils.ServiceType
Master Raft service (Netty).
MASTER_RECURSIVE_OPERATION_JOURNAL_FORCE_FLUSH_MAX_ENTRIES - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RECURSIVE_OPERATION_JOURNAL_FORCE_FLUSH_MAX_ENTRIES - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RENAME_PATH_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_REPLICA_MGMT_ACTIVE_JOB_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_REPLICATION_CHECK - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_REPLICATION_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_REPLICATION_CHECK_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_REPLICATION_CHECK_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_ROCKS_BLOCK_BACKGROUND_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_BLOCK_CACHE_CAPACITY - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_BLOCK_CACHE_PINNED_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_BLOCK_CACHE_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_COMPACTION_PENDING - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_CUR_SIZE_ACTIVE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_CUR_SIZE_ALL_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_ESTIMATE_NUM_KEYS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_ESTIMATE_PENDING_COMPACTION_BYTES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_ESTIMATE_TABLE_READERS_MEM - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_ESTIMATED_MEM_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_LIVE_SST_FILES_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_MEM_TABLE_FLUSH_PENDING - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_DELETES_ACTIVE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_DELETES_IMM_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_ENTRIES_ACTIVE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_ENTRIES_IMM_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_IMMUTABLE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_LIVE_VERSIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_RUNNING_COMPACTIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_NUM_RUNNING_FLUSHES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_SIZE_ALL_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_BLOCK_TOTAL_SST_FILES_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_BACKGROUND_ERRORS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_BLOCK_CACHE_CAPACITY - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_BLOCK_CACHE_PINNED_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_BLOCK_CACHE_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_COMPACTION_PENDING - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_CUR_SIZE_ACTIVE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_CUR_SIZE_ALL_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_ESTIMATE_NUM_KEYS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_ESTIMATE_PENDING_COMPACTION_BYTES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_ESTIMATE_TABLE_READERS_MEM - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_ESTIMATED_MEM_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_LIVE_SST_FILES_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_MEM_TABLE_FLUSH_PENDING - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_DELETES_ACTIVE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_DELETES_IMM_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_ENTRIES_ACTIVE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_ENTRIES_IMM_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_IMMUTABLE_MEM_TABLE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_LIVE_VERSIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_RUNNING_COMPACTIONS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_NUM_RUNNING_FLUSHES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_SIZE_ALL_MEM_TABLES - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_INODE_TOTAL_SST_FILES_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROCKS_TOTAL_ESTIMATED_MEM_USAGE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_ROLE_ID - Static variable in class alluxio.metrics.MetricKey
 
MASTER_RPC - alluxio.util.network.NetworkAddressUtils.ServiceType
Master RPC service (gRPC).
MASTER_RPC_ADDRESSES - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_ADDRESSES - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_CORE_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_CORE_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_FJP_ASYNC - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_FJP_ASYNC - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_FJP_MIN_RUNNABLE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_FJP_MIN_RUNNABLE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_FJP_PARALLELISM - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_FJP_PARALLELISM - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_KEEPALIVE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_KEEPALIVE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_MAX_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_MAX_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_TPE_ALLOW_CORE_THREADS_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_TPE_ALLOW_CORE_THREADS_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_TPE_QUEUE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_TPE_QUEUE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_EXECUTOR_TYPE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_EXECUTOR_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_RPC_QUEUE_LENGTH - Static variable in class alluxio.metrics.MetricKey
 
MASTER_RPC_THREAD_ACTIVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_RPC_THREAD_CURRENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_SERVING_THREAD_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SERVING_THREAD_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SET_ACL_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_SET_ATTRIBUTE_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_GRACE_MODE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_GRACE_MODE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SHELL_BACKUP_STATE_LOCK_SLEEP_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_SLEEP_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SHELL_BACKUP_STATE_LOCK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SHELL_BACKUP_STATE_LOCK_TRY_DURATION - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SHELL_BACKUP_STATE_LOCK_TRY_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_SKIP_ROOT_ACL_CHECK - Static variable in class alluxio.conf.PropertyKey
 
MASTER_SKIP_ROOT_ACL_CHECK - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_STANDBY_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_STANDBY_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_STARTUP_BLOCK_INTEGRITY_CHECK_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_STARTUP_BLOCK_INTEGRITY_CHECK_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TABLE_TRANSFORMATION_MONITOR - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_TABLE_TRANSFORMATION_MONITOR - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_THROTTLE - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_THROTTLE - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_THROTTLE_ACTIVE_CPU_LOAD_RATIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_ACTIVE_CPU_LOAD_RATIO - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_ACTIVE_HEAP_GC_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_ACTIVE_HEAP_GC_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_ACTIVE_HEAP_USED_RATIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_ACTIVE_HEAP_USED_RATIO - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_ACTIVE_RPC_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_ACTIVE_RPC_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_BACKGROUND_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_BACKGROUND_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_FILESYSTEM_OP_PER_SEC - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_FILESYSTEM_OP_PER_SEC - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_FILESYSTEM_RPC_QUEUE_SIZE_LIMIT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_FILESYSTEM_RPC_QUEUE_SIZE_LIMIT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_FOREGROUND_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_FOREGROUND_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_HEARTBEAT_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_OBSERVED_PIT_NUMBER - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_OBSERVED_PIT_NUMBER - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_OVERLOADED_CPU_LOAD_RATIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_OVERLOADED_CPU_LOAD_RATIO - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_OVERLOADED_HEAP_GC_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_OVERLOADED_HEAP_GC_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_OVERLOADED_HEAP_USED_RATIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_OVERLOADED_HEAP_USED_RATIO - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_OVERLOADED_RPC_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_OVERLOADED_RPC_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_STRESSED_CPU_LOAD_RATIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_STRESSED_CPU_LOAD_RATIO - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_STRESSED_HEAP_GC_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_STRESSED_HEAP_GC_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_STRESSED_HEAP_USED_RATIO - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_STRESSED_HEAP_USED_RATIO - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_THROTTLE_STRESSED_RPC_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_THROTTLE_STRESSED_RPC_QUEUE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_LEVEL_ALIAS - alluxio.conf.PropertyKey.Template
 
MASTER_TIERED_STORE_GLOBAL_LEVEL0_ALIAS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVEL0_ALIAS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_LEVEL1_ALIAS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVEL1_ALIAS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_LEVEL2_ALIAS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVEL2_ALIAS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_LEVELS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_LEVELS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TIERED_STORE_GLOBAL_MEDIUMTYPE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TIERED_STORE_GLOBAL_MEDIUMTYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_TO_REMOVE_BLOCK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_TOTAL_BLOCK_REPLICA_COUNT - Static variable in class alluxio.metrics.MetricKey
 
MASTER_TOTAL_PATHS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_TOTAL_RPCS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_TTL_CHECK - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_TTL_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_TTL_CHECKER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_TTL_CHECKER_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_EVENT_RATE_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_EVENT_RATE_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_INITIAL_SYNC_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_INITIAL_SYNC_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_MAX_ACTIVITIES - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_MAX_ACTIVITIES - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_MAX_AGE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_MAX_AGE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_POLL_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_POLL_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_POLL_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_POLL_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_RETRY_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_RETRY_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_ACTIVE_SYNC_THREAD_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_ACTIVE_SYNC_THREAD_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_BLOCK_LOCATION_CACHE_CAPACITY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_BLOCK_LOCATION_CACHE_CAPACITY - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_CLEANUP - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_UFS_CLEANUP - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_UFS_JOURNAL_CATCHUP_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UFS_JOURNAL_FAILURE_RECOVER_TIMER - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UFS_JOURNAL_INITIAL_REPLAY_TIME_MS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UFS_JOURNAL_MAX_CATCHUP_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_JOURNAL_MAX_CATCHUP_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_MANAGED_BLOCKING_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_MANAGED_BLOCKING_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_PATH_CACHE_CAPACITY - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_PATH_CACHE_CAPACITY - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_PATH_CACHE_THREADS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UFS_PATH_CACHE_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UFS_STATUS_CACHE_CHILDREN_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UFS_STATUS_CACHE_SIZE - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UNIQUE_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UNMOUNT_OPS - Static variable in class alluxio.metrics.MetricKey
 
MASTER_UNSAFE_DIRECT_PERSIST_OBJECT_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UNSAFE_DIRECT_PERSIST_OBJECT_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UPDATE_CHECK - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_UPDATE_CHECK - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_UPDATE_CHECK_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UPDATE_CHECK_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_UPDATE_CHECK_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_UPDATE_CHECK_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WEB - alluxio.util.network.NetworkAddressUtils.ServiceType
Master web service (Jetty).
MASTER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WEB_IN_ALLUXIO_DATA_PAGE_COUNT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WEB_IN_ALLUXIO_DATA_PAGE_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WEB_JOURNAL_CHECKPOINT_WARNING_THRESHOLD_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WEB_JOURNAL_CHECKPOINT_WARNING_THRESHOLD_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WHITELIST - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WHITELIST - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_CONNECT_WAIT_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_CONNECT_WAIT_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_INFO_CACHE_REFRESH_TIME - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_INFO_CACHE_REFRESH_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_REGISTER_LEASE_COUNT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_REGISTER_LEASE_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_REGISTER_LEASE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_REGISTER_LEASE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_REGISTER_LEASE_RESPECT_JVM_SPACE - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_REGISTER_LEASE_RESPECT_JVM_SPACE - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_REGISTER_LEASE_TTL - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_REGISTER_LEASE_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_REGISTER_SESSION_CLEANER - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
MASTER_WORKER_REGISTER_SESSION_CLEANER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MASTER_WORKER_REGISTER_STREAM_RESPONSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_REGISTER_STREAM_RESPONSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
MASTER_WORKER_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
MASTER_WORKER_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
MasterClientContext - Class in alluxio.master
Configuration for constructing an Alluxio master client.
MasterClientContext(ClientContext, MasterInquireClient) - Constructor for class alluxio.master.MasterClientContext
 
MasterClientContextBuilder - Class in alluxio.master
This class can be used to obtain instances of a MasterClientContext.
MasterClientContextBuilder(ClientContext) - Constructor for class alluxio.master.MasterClientContextBuilder
Create an instance of a MasterClientContextBuilder.
masterHostConfigured(AlluxioConfiguration) - Static method in class alluxio.util.ConfigurationUtils
 
MasterInfo - Class in alluxio.wire
Master information.
MasterInfo() - Constructor for class alluxio.wire.MasterInfo
Creates a new instance of MasterInfo.
MasterInfo(long, Address) - Constructor for class alluxio.wire.MasterInfo
Creates a new instance of MasterInfo.
MasterInfo(long, Address, long) - Constructor for class alluxio.wire.MasterInfo
Creates a new instance of MasterInfo.
MasterInquireClient - Interface in alluxio.master
Client for determining the primary master.
MasterInquireClient.ConnectDetails - Interface in alluxio.master
Interface for representing master inquire connect details.
MasterInquireClient.Factory - Class in alluxio.master
Factory for getting a master inquire client.
MasterSelectionPolicy - Interface in alluxio.master.selectionpolicy
Interface for master selection policy that determines which master node a client should connect to.
MasterSelectionPolicy.Factory - Class in alluxio.master.selectionpolicy
MasterWebUIBrowse - Class in alluxio.wire
Alluxio WebUI browse information.
MasterWebUIBrowse() - Constructor for class alluxio.wire.MasterWebUIBrowse
Creates a new instance of MasterWebUIBrowse.
MasterWebUIConfiguration - Class in alluxio.wire
Alluxio WebUI configuration information.
MasterWebUIConfiguration() - Constructor for class alluxio.wire.MasterWebUIConfiguration
Creates a new instance of MasterWebUIConfiguration.
MasterWebUIData - Class in alluxio.wire
Alluxio WebUI memory information.
MasterWebUIData() - Constructor for class alluxio.wire.MasterWebUIData
Creates a new instance of MasterWebUIData.
MasterWebUIInit - Class in alluxio.wire
Alluxio WebUI overview information.
MasterWebUIInit() - Constructor for class alluxio.wire.MasterWebUIInit
Creates a new instance of MasterWebUIInit.
MasterWebUILogs - Class in alluxio.wire
Alluxio WebUI logs information.
MasterWebUILogs() - Constructor for class alluxio.wire.MasterWebUILogs
Creates a new instance of MasterWebUIWorkers.
MasterWebUIMasters - Class in alluxio.wire
Alluxio WebUI masters information.
MasterWebUIMasters() - Constructor for class alluxio.wire.MasterWebUIMasters
Creates a new instance of MasterWebUIMasters.
MasterWebUIMetrics - Class in alluxio.wire
Alluxio WebUI metrics information.
MasterWebUIMetrics() - Constructor for class alluxio.wire.MasterWebUIMetrics
Creates a new instance of MasterWebUIMetrics.
MasterWebUIMountTable - Class in alluxio.wire
Alluxio WebUI mount table information.
MasterWebUIMountTable() - Constructor for class alluxio.wire.MasterWebUIMountTable
Creates a new instance of MasterWebUIMountTable.
MasterWebUIOverview - Class in alluxio.wire
Alluxio WebUI overview information.
MasterWebUIOverview() - Constructor for class alluxio.wire.MasterWebUIOverview
Creates a new instance of MasterWebUIOverview.
MasterWebUIWorkers - Class in alluxio.wire
Alluxio WebUI workers information.
MasterWebUIWorkers() - Constructor for class alluxio.wire.MasterWebUIWorkers
Creates a new instance of MasterWebUIWorkers.
match(AlluxioURI) - Method in interface alluxio.conf.path.PathMatcher
 
match(AlluxioURI) - Method in class alluxio.conf.path.PrefixPathMatcher
 
match(String) - Method in enum alluxio.conf.PropertyKey.Template
 
matchContent(Fingerprint) - Method in class alluxio.underfs.Fingerprint
Returns true if the serialized fingerprint matches the fingerprint in the content part.
matches(TieredIdentity.LocalityTier, TieredIdentity.LocalityTier, boolean) - Static method in class alluxio.util.TieredIdentityUtils
Locality comparison for wire type locality tiers, two locality tiers matches if both name and values are equal, or for the "node" tier, if the node names resolve to the same IP address.
matches(String) - Method in enum alluxio.client.quota.CacheScope.Level
 
matches(String) - Method in enum alluxio.conf.PropertyKey.Template
 
matches(String, Metric) - Method in class alluxio.metrics.sink.RegexMetricFilter
 
matchIncreasingByteArray(int, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array has a sub array equals an increasing sequence of bytes, starting from 0.
matchIncreasingByteArray(int, int, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array has a sub array equals an increasing sequence of bytes, starting from the given value.
matchIncreasingByteBuffer(int, int, int, ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte buffer has a sub buffer equals an increasing sequence of bytes, starting from the given value.
matchIncreasingByteBuffer(int, int, ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte buffer has a sub buffer equals an increasing sequence of bytes, starting from the given value.
matchMetadata(Fingerprint) - Method in class alluxio.underfs.Fingerprint
Returns true if the serialized fingerprint matches the fingerprint in metadata.
mAuthority - Variable in class alluxio.uri.StandardURI
 
MAX_PORT - Static variable in class alluxio.Constants
 
MAX_TEST_DURATION_MS - Static variable in class alluxio.Constants
 
MAX_TEST_PROCESS_LIFETIME_MS - Static variable in class alluxio.Constants
 
MAX_TRUNCATED_LENGTH - Static variable in class alluxio.util.LogUtils
The truncated length for a message line.
maxInboundMessageSize(int) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the maximum size of inbound messages.
MaxReservoir - Class in alluxio.metrics
A wrapper around Reservoir that keeps track of the max value sent as an update to this reservoir.
MaxReservoir(Reservoir) - Constructor for class alluxio.metrics.MaxReservoir
 
MB - Static variable in class alluxio.Constants
 
mBlockSize - Variable in class alluxio.underfs.UfsFileStatus
 
mBucketName - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
Bucket name of the object storage bucket.
mBuffer - Variable in class alluxio.network.protocol.databuffer.NioDataBuffer
 
mChannel - Variable in class alluxio.AbstractClient
Underlying channel to the target service.
mChannels - Variable in class alluxio.security.authentication.DefaultAuthenticationServer
List of channels authenticated against this server.
mCleanupIntervalMs - Variable in class alluxio.security.authentication.DefaultAuthenticationServer
Interval for clean-up task to fire.
mClock - Variable in class alluxio.resource.DynamicResourcePool
 
mClosed - Variable in class alluxio.AbstractClient
Is true if this client was closed by the user.
mClosed - Variable in class alluxio.underfs.MultiRangeObjectInputStream
Has the stream been closed.
mClosed - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
Flag to indicate this stream has been closed, to ensure close is only done once.
mCloser - Variable in class alluxio.cli.AbstractShell
 
mConf - Variable in class alluxio.security.user.BaseUserState
 
mConfAddress - Variable in class alluxio.AbstractJobMasterClient
Address to load configuration, which may differ from mAddress.
mConfiguration - Variable in class alluxio.cli.AbstractShell
 
mConfiguration - Variable in class alluxio.security.authentication.DefaultAuthenticationServer
Alluxio client configuration.
mConnected - Variable in class alluxio.AbstractClient
Is true if this client is currently connected.
mContentHash - Variable in class alluxio.underfs.UfsFileStatus
 
mContentLength - Variable in class alluxio.underfs.UfsFileStatus
 
mContext - Variable in class alluxio.AbstractClient
Context of the client.
mContext - Variable in class alluxio.master.MasterClientContextBuilder
 
mCurrentCapacity - Variable in class alluxio.resource.ResourcePool
It represents the total number of resources that have been created by this pool.
MECHANISM - Static variable in class alluxio.security.authentication.plain.PlainSaslServerProvider
 
MEDIUM_HDD - Static variable in class alluxio.Constants
 
MEDIUM_MEM - Static variable in class alluxio.Constants
 
MEDIUM_SSD - Static variable in class alluxio.Constants
 
mediumType() - Method in class alluxio.worker.block.BlockStoreLocation
Gets the medium type of the location.
MEM - alluxio.client.file.cache.store.PageStoreType
A simple store with pages on the memory (HeapByteBuffer).
memoize(Supplier<T>) - Static method in class alluxio.util.CommonUtils
Memoize implementation for java.util.function.supplier.
mEndPos - Variable in class alluxio.underfs.MultiRangeObjectInputStream
Position the current stream was open till (exclusive).
mEntriesAdded - Variable in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Total number of inputs to be operated on across batches.
merge(AclActions) - Method in class alluxio.security.authorization.AclActions
Merges the actions.
merge(Map<?, ?>, Source) - Method in class alluxio.conf.AlluxioProperties
Merges the current configuration properties with new properties.
merge(Map<?, ?>, Source) - Static method in class alluxio.conf.Configuration
Merges the current configuration properties with new properties.
merge(Map<?, ?>, Source) - Method in class alluxio.conf.InstancedConfiguration
Merges map of properties into the current alluxio properties.
MESOS_LOCAL_INSTALL - Static variable in class alluxio.Constants
 
message() - Method in annotation type alluxio.conf.Deprecated
A message to the user which could suggest an alternative key.
META_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
META_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
META_MASTER_CONFIG_SERVICE_NAME - Static variable in class alluxio.Constants
 
META_MASTER_CONFIG_SERVICE_VERSION - Static variable in class alluxio.Constants
 
META_MASTER_MASTER_SERVICE_NAME - Static variable in class alluxio.Constants
 
META_MASTER_MASTER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
META_MASTER_NAME - Static variable in class alluxio.Constants
 
META_MASTER_SYNC - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
META_MASTER_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
MetadataSyncTraversalOrder - Enum in alluxio.master.file
The pending Path in the Inode SyncStream traversal order.
METASTORE_URI_CONFIG_NAME - Static variable in class alluxio.cli.ValidationConfig
 
METASTORE_URI_OPTION_NAME - Static variable in class alluxio.cli.ValidationConfig
 
MetastoreType - Enum in alluxio.master.metastore
Metastore types.
meter(String) - Static method in class alluxio.metrics.MetricsSystem
Get or add meter with the given name.
meterWithTags(String, boolean, String...) - Static method in class alluxio.metrics.MetricsSystem
Get or add meter with the given name.
Metric - Class in alluxio.metrics
A metric of a given instance.
Metric(MetricsSystem.InstanceType, String, MetricType, String, Double) - Constructor for class alluxio.metrics.Metric
Constructs a Metric instance.
METRIC_REGISTRY - Static variable in class alluxio.metrics.MetricsSystem
 
MetricInfo - Class in alluxio.metrics
Metric information.
MetricInfo.UfsOps - Enum in alluxio.metrics
The list of under filesystem operations triggered by master or workers.
MetricKey - Class in alluxio.metrics
Metric keys.
MetricKey.Builder - Class in alluxio.metrics
Builder to create MetricKey instances.
MetricKey.Name - Class in alluxio.metrics
A nested class to hold named string constants for their corresponding metrics.
METRICS_CONF_FILE - Static variable in class alluxio.conf.PropertyKey
 
METRICS_CONF_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
METRICS_CONTEXT_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
METRICS_CONTEXT_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
METRICS_EXECUTOR_TASK_WARN_FREQUENCY - Static variable in class alluxio.conf.PropertyKey
 
METRICS_EXECUTOR_TASK_WARN_FREQUENCY - Static variable in class alluxio.conf.PropertyKey.Name
 
METRICS_EXECUTOR_TASK_WARN_SIZE - Static variable in class alluxio.conf.PropertyKey
 
METRICS_EXECUTOR_TASK_WARN_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
METRICS_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
METRICS_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
METRICS_MASTER_NAME - Static variable in class alluxio.Constants
 
MetricsAggregator - Interface in alluxio.metrics
Interface for the aggregator that aggregates a cluster-level metric from the metrics of different hosts.
MetricsConfig - Class in alluxio.metrics
Configurations used by the metrics system.
MetricsConfig(String) - Constructor for class alluxio.metrics.MetricsConfig
Creates a new MetricsConfig using the given config file.
MetricsConfig(Properties) - Constructor for class alluxio.metrics.MetricsConfig
Creates a new MetricsConfig using the given Properties.
MetricsFilter - Class in alluxio.metrics
A filter that matches the instance-level metrics by the instance type and metric name.
MetricsFilter(MetricsSystem.InstanceType, String) - Constructor for class alluxio.metrics.MetricsFilter
Constructs a new MetricsFilter instance.
MetricsSystem - Class in alluxio.metrics
A MetricsSystem is created by a specific instance(master, worker).
MetricsSystem.InstanceType - Enum in alluxio.metrics
An enum of supported instance type.
MetricsSystem.MultiTimerContext - Class in alluxio.metrics
A timer context with multiple timers.
mExecutorService - Variable in class alluxio.underfs.ObjectUnderFileSystem
Executor service used for parallel UFS operations such as bulk deletes.
mExpiryTimeMs - Variable in class alluxio.wire.RegisterLease
 
mExtendedEntries - Variable in class alluxio.security.authorization.AccessControlList
 
mFile - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
The local temp file that will be uploaded when reaches the partition size or when flush() is called and this file is bigger than ObjectLowLevelOutputStream.UPLOAD_THRESHOLD.
mGroup - Variable in class alluxio.underfs.UfsStatus
 
mHash - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
The MD5 hash of the file.
mHashCode - Variable in class alluxio.uri.StandardURI
 
mHostName - Variable in class alluxio.security.authentication.DefaultAuthenticationServer
Address of the authentication host.
MIGRATE_CANNOT_BE_TO_SUBDIRECTORY - alluxio.exception.ExceptionMessage
 
MIGRATE_DATA_SESSION_ID - Static variable in class alluxio.Sessions
 
millis() - Method in class alluxio.clock.ElapsedTimeClock
 
millis() - Method in class alluxio.clock.SystemClock
 
minimalCompletionStage() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletionStage that is completed normally with the same value as this CompletableFuture when it completes normally, and cannot be independently completed or otherwise used in ways not defined by the methods of interface CompletionStage.
MINUTE - Static variable in class alluxio.Constants
 
MINUTE_MS - Static variable in class alluxio.Constants
 
MINUTE_SECONDS - Static variable in class alluxio.Constants
 
mIsDirectory - Variable in class alluxio.underfs.UfsStatus
 
mkdirIfNotExists(UnderFileSystem, String) - Static method in class alluxio.util.UnderFileSystemUtils
Attempts to create the directory if it does not already exist.
mkdirs(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
mkdirs(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
mkdirs(String) - Method in interface alluxio.underfs.UnderFileSystem
Creates the directory named by this abstract pathname.
mkdirs(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
mkdirs(String, MkdirsOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
mkdirs(String, MkdirsOptions) - Method in interface alluxio.underfs.UnderFileSystem
Creates the directory named by this abstract pathname, with specified MkdirsOptions.
mkdirs(String, MkdirsOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
MKDIRS - alluxio.metrics.MetricInfo.UfsOps
 
mkdirsInternal(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Creates a directory flagged file with the key and folder suffix.
MkdirsOptions - Class in alluxio.underfs.options
Method options for mkdirs in UnderFileSystem.
mKey - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
Key of the file when it is uploaded to object storage.
mLastModifiedTimeMs - Variable in class alluxio.underfs.UfsStatus
Last modified epoch time in ms, or null if it is not available.
mLength - Variable in class alluxio.network.protocol.databuffer.NioDataBuffer
 
mLocalOutputStream - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
The output stream to the local temp file.
mLock - Variable in class alluxio.resource.LockResource
 
mMaskActions - Variable in class alluxio.security.authorization.ExtendedACLEntries
 
mMasterInquireClient - Variable in class alluxio.master.MasterClientContextBuilder
 
mMaxCapacity - Variable in class alluxio.resource.ResourcePool
 
mMode - Variable in class alluxio.security.authorization.AccessControlList
 
mMode - Variable in class alluxio.underfs.UfsStatus
 
mName - Variable in class alluxio.underfs.UfsStatus
 
mNamedGroupActions - Variable in class alluxio.security.authorization.ExtendedACLEntries
 
mNamedUserActions - Variable in class alluxio.security.authorization.ExtendedACLEntries
 
Mode - Class in alluxio.security.authorization
POSIX style file/directory access mode.
Mode(short) - Constructor for class alluxio.security.authorization.Mode
Constructs an instance of Mode with the given mode.
Mode(Mode) - Constructor for class alluxio.security.authorization.Mode
Copy constructor.
Mode(Mode.Bits, Mode.Bits, Mode.Bits) - Constructor for class alluxio.security.authorization.Mode
Constructs an instance of Mode with the given Mode.Bits.
MODE - alluxio.underfs.Fingerprint.Tag
 
MODE_BITS_ALL - Static variable in class alluxio.Constants
 
MODE_BITS_EXECUTE - Static variable in class alluxio.Constants
 
MODE_BITS_NONE - Static variable in class alluxio.Constants
 
MODE_BITS_READ - Static variable in class alluxio.Constants
 
MODE_BITS_READ_EXECUTE - Static variable in class alluxio.Constants
 
MODE_BITS_READ_WRITE - Static variable in class alluxio.Constants
 
MODE_BITS_WRITE - Static variable in class alluxio.Constants
 
MODE_BITS_WRITE_EXECUTE - Static variable in class alluxio.Constants
 
Mode.Bits - Enum in alluxio.security.authorization
Mode bits.
ModeParser - Class in alluxio.security.authorization
Parser for Mode instances.
ModeUtils - Class in alluxio.util
Utility methods for mode.
modifiableGlobal() - Static method in class alluxio.conf.Configuration
 
MOUNT_COMMAND - Static variable in class alluxio.util.ShellUtils
a Unix command for getting mount information.
MOUNT_OPTION - alluxio.conf.Source.Type
The property value is specified as options for a mount point.
MOUNT_OPTION - Static variable in class alluxio.conf.Source
 
MOUNT_POINT_ALREADY_EXISTS - alluxio.exception.ExceptionMessage
 
MOUNT_POINT_PREFIX_OF_ANOTHER - alluxio.exception.ExceptionMessage
 
MOUNT_READONLY - alluxio.exception.ExceptionMessage
 
MountPointInfo - Class in alluxio.wire
The mount point information.
MountPointInfo() - Constructor for class alluxio.wire.MountPointInfo
Creates a new instance of MountPointInfo.
move(String, String) - Static method in class alluxio.util.io.FileUtils
Moves file from one place to another, can across storage devices (e.g., from memory to SSD) when File.renameTo(java.io.File) may not work.
moveBlock(long, long, AllocateOptions) - Method in interface alluxio.worker.block.BlockStore
Moves an existing block to a new location.
moveBlock(long, long, String) - Method in interface alluxio.worker.block.BlockWorker
Moves a block from its current location to a target location, currently only tier level moves are supported.
mOwner - Variable in class alluxio.underfs.UfsStatus
 
mOwningGroup - Variable in class alluxio.security.authorization.AccessControlList
 
mOwningUser - Variable in class alluxio.security.authorization.AccessControlList
 
mPartitionOffset - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
When the offset reaches the partition size, we upload the temp file.
mPartitionSize - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
The maximum allowed size of a partition.
mPath - Variable in class alluxio.uri.StandardURI
 
mPool - Variable in class alluxio.resource.PooledResource
 
mPoolDescription - Variable in class alluxio.resource.PooledResource
 
mPos - Variable in class alluxio.underfs.MultiRangeObjectInputStream
The current position of the stream.
mPrimaryMasterAddress - Variable in class alluxio.master.selectionpolicy.AbstractMasterSelectionPolicy
 
mProperties - Variable in class alluxio.conf.InstancedConfiguration
Source of the truth of all property values (default or customized).
mQuery - Variable in class alluxio.uri.StandardURI
 
mResources - Variable in class alluxio.resource.ResourcePool
 
mRetryPolicy - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
The retry policy of this multipart upload.
mRootKeySupplier - Variable in class alluxio.underfs.ObjectUnderFileSystem
The root key of an object fs.
MS_NANO - Static variable in class alluxio.Constants
 
mSaslClient - Variable in class alluxio.security.authentication.AbstractSaslClientHandler
Underlying SaslClient.
mSaslServer - Variable in class alluxio.security.authentication.AbstractSaslServerHandler
Underlying SaslServer.
mScheduler - Variable in class alluxio.security.authentication.DefaultAuthenticationServer
Scheduler for periodic cleaning of channels registry.
mScheme - Variable in class alluxio.uri.StandardURI
A hierarchical URI.
mSchemeSpecificPart - Variable in class alluxio.uri.StandardURI
 
mServerAddress - Variable in class alluxio.AbstractClient
Grpc Address of the remote server.
mServiceVersion - Variable in class alluxio.AbstractClient
Stores the actual remote service version, used to compare with expected local version.
mSingleCharWrite - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
Pre-allocated byte buffer for writing single characters.
mStream - Variable in class alluxio.underfs.MultiRangeObjectInputStream
The backing input stream.
mSubject - Variable in class alluxio.security.user.BaseUserState
 
mTmpDirs - Variable in class alluxio.underfs.ObjectLowLevelOutputStream
 
mType - Variable in class alluxio.conf.Source
 
mUfsConf - Variable in class alluxio.underfs.BaseUnderFileSystem
UFS Configuration options.
MULTI_MASTERS_AUTH - Static variable in interface alluxio.uri.Authority
 
MultiMasterAuthority - Class in alluxio.uri
A multi-master authority implementation.
MultiMasterAuthority(String) - Constructor for class alluxio.uri.MultiMasterAuthority
 
MultiMasterConnectDetails(List<InetSocketAddress>) - Constructor for class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
MultiPartSchemeURI - Class in alluxio.uri
MultiPartSchemeURI supports multiple components for the scheme.
MultiPartSchemeURI(URI, String, String) - Constructor for class alluxio.uri.MultiPartSchemeURI
Constructs a new URI from a base URI, but with a new path component.
MultiPartSchemeURI(String, String, Authority, String, String) - Constructor for class alluxio.uri.MultiPartSchemeURI
 
MULTIPLE_BLOOM_FILTER - alluxio.client.file.cache.ShadowCacheType
A shadow cache with multiple bloom filter implementation.
MultiRangeObjectInputStream - Class in alluxio.underfs
A stream for reading data using range queries.
MultiRangeObjectInputStream(long) - Constructor for class alluxio.underfs.MultiRangeObjectInputStream
Creates the input stream that will perform reads with a specified chunk size.
MultiTimerContext(Timer...) - Constructor for class alluxio.metrics.MetricsSystem.MultiTimerContext
 
MultiValueMetricsAggregator - Interface in alluxio.metrics
An interface for the aggregator that aggregates metrics of different hosts into multiple cluster-level metrics.
mUri - Variable in class alluxio.underfs.BaseUnderFileSystem
The UFS AlluxioURI used to create this BaseUnderFileSystem.
mUser - Variable in class alluxio.security.user.BaseUserState
 
MUST_CACHE - alluxio.client.WriteType
Write the file, guaranteeing the data is written to Alluxio storage or failing the operation.
mVersionService - Variable in class alluxio.AbstractClient
 
mXAttr - Variable in class alluxio.underfs.UfsStatus
 

N

Name() - Constructor for class alluxio.metrics.MetricKey.Name
 
NAME - Static variable in class alluxio.security.authentication.plain.PlainSaslServerProvider
 
NAMED_GROUP - alluxio.security.authorization.AclEntryType
 
NAMED_USER - alluxio.security.authorization.AclEntryType
 
NANO - alluxio.client.file.CacheContext.StatsUnit
 
nearest(TieredIdentity, List<TieredIdentity>, AlluxioConfiguration) - Static method in class alluxio.util.TieredIdentityUtils
 
needsNormalization(String) - Static method in class alluxio.util.URIUtils
Returns true if the path requires normalization.
netAddressToSocketAddress(List<NetAddress>) - Static method in class alluxio.grpc.GrpcUtils
Convert a list of NetAddress to InetSocketAddress.
NETTY_CHANNEL_COUNT - Static variable in class alluxio.metrics.MetricKey
 
NettyBufTargetBuffer - Class in alluxio.file
Netty Buf backed target buffer for zero-copy read from page store.
NettyBufTargetBuffer(ByteBuf) - Constructor for class alluxio.file.NettyBufTargetBuffer
 
NettyChannelPool - Class in alluxio.network.netty
A pool to manage netty channels.
NettyChannelPool(Bootstrap, int, long) - Constructor for class alluxio.network.netty.NettyChannelPool
Creates a netty channel pool instance with a minimum capacity of 1.
NettyClient - Class in alluxio.network.netty
Shared configuration and methods for the Netty client.
NettyDataBuffer - Class in alluxio.network.protocol.databuffer
A DataBuffer with the underlying data being a ByteBuf.
NettyDataBuffer(ByteBuf) - Constructor for class alluxio.network.protocol.databuffer.NettyDataBuffer
Constructor for creating a NettyDataBuffer, by passing a Netty ByteBuf.
NettyRPC - Class in alluxio.network.netty
Netty blocking RPC client.
NettyRPC.RPCHandler - Class in alluxio.network.netty
Netty RPC client handler.
NettyRPCContext - Class in alluxio.network.netty
Context to send a netty RPC.
NettyUtils - Class in alluxio.util.network
Utility methods for working with Netty.
NETWORK_CONNECTION_AUTH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_CONNECTION_AUTH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_CONNECTION_HEALTH_CHECK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_CONNECTION_HEALTH_CHECK_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_CONNECTION_SERVER_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_CONNECTION_SERVER_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_CONNECTION_SHUTDOWN_GRACEFUL_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_CONNECTION_SHUTDOWN_GRACEFUL_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_CONNECTION_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_CONNECTION_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_HOST_RESOLUTION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_HOST_RESOLUTION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_IP_ADDRESS_USED - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_IP_ADDRESS_USED - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_NETTY_HEARTBEAT_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_NETTY_HEARTBEAT_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_TLS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_TLS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
NETWORK_TLS_SSL_CONTEXT_PROVIDER_CLASSNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
NETWORK_TLS_SSL_CONTEXT_PROVIDER_CLASSNAME - Static variable in class alluxio.conf.PropertyKey
 
NetworkAddressUtils - Class in alluxio.util.network
Common network address related utilities shared by all components in Alluxio.
NetworkAddressUtils.ServiceAttributeProvider - Interface in alluxio.util.network
An interface to get service attributes.
NetworkAddressUtils.ServiceType - Enum in alluxio.util.network
Different types of services that client uses to connect.
NEVER - alluxio.wire.LoadMetadataType
Never loads metadata.
NEVER - Static variable in class alluxio.util.WaitForOptions
 
newBuilder() - Static method in class alluxio.job.JobDescription
 
newBuilder() - Static method in class alluxio.wire.Configuration
 
newBuilder(ClientContext) - Static method in class alluxio.master.MasterClientContext
Create an instance of a MasterClientContextBuilder which can be used to obtain and instance of MasterClientContext.
newBuilder(GrpcServerAddress, AlluxioConfiguration) - Static method in class alluxio.grpc.GrpcChannelBuilder
Create a channel builder for given address using the given configuration.
newByteArrayFromByteBuffer(ByteBuffer) - Static method in class alluxio.util.io.BufferUtils
Creates a byte array from the given ByteBuffer, the position property of input ByteBuffer remains unchanged.
newCall(MethodDescriptor<RequestT, ResponseT>, CallOptions) - Method in class alluxio.grpc.GrpcChannel
 
newIncompleteFuture() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new incomplete CompletableFuture of the type to be returned by a CompletionStage method.
newResourceLeakDetector(Class<T>, int) - Method in class alluxio.resource.AlluxioResourceLeakDetectorFactory
 
newResourceLeakDetector(Class<T>, int, long) - Method in class alluxio.resource.AlluxioResourceLeakDetectorFactory
 
newTaskFor(Runnable, T) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
newTaskFor(Callable<T>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
newThread(ForkJoinPool) - Method in class alluxio.concurrent.jsr.ForkJoinPool.AlluxioForkJoinWorkerThreadFactory
 
newThread(ForkJoinPool) - Method in interface alluxio.concurrent.jsr.ForkJoinPool.ForkJoinWorkerThreadFactory
Returns a new worker thread operating in the given pool.
next() - Method in class alluxio.resource.CloseableIterator
 
next(RocksIterator) - Method in interface alluxio.master.metastore.rocks.RocksUtils.RocksIteratorParser
Parses and return next element.
nextComplete() - Method in class alluxio.concurrent.jsr.CountedCompleter
If this task does not have a completer, invokes ForkJoinTask.quietlyComplete() and returns null.
NIO - alluxio.network.ChannelType
 
NioDataBuffer - Class in alluxio.network.protocol.databuffer
A DataBuffer with the underlying data being a ByteBuffer.
NioDataBuffer(ByteBuffer, long) - Constructor for class alluxio.network.protocol.databuffer.NioDataBuffer
 
NioDirectBufferPool - Class in alluxio.network.protocol.databuffer
Direct buffer pool.
NioDirectBufferPool() - Constructor for class alluxio.network.protocol.databuffer.NioDirectBufferPool
 
NO_ACCESS - alluxio.underfs.UfsMode
 
NO_AUTO_PERSIST - Static variable in class alluxio.Constants
 
NO_BLOCK_ID_FOUND - alluxio.exception.ExceptionMessage
 
NO_CACHE - alluxio.client.ReadType
Read the file and skip Alluxio storage.
NO_EVICTION_PLAN_TO_FREE_SPACE - alluxio.exception.ExceptionMessage
 
NO_LOCAL_BLOCK_WORKER_LOAD_TASK - alluxio.exception.ExceptionMessage
 
NO_PERSIST - alluxio.client.UnderStorageType
Do not persist data to the under storage.
NO_SCHEME - Static variable in class alluxio.Constants
 
NO_SPACE_FOR_BLOCK_META - alluxio.exception.ExceptionMessage
 
NO_SPACE_FOR_BLOCK_MOVE - alluxio.exception.ExceptionMessage
 
NO_SPACE_FOR_BLOCK_ON_WORKER - alluxio.exception.ExceptionMessage
 
NO_STORE - alluxio.client.AlluxioStorageType
Do not put data to Alluxio.
NO_TTL - Static variable in class alluxio.Constants
 
NO_WORKER_AVAILABLE - alluxio.exception.ExceptionMessage
 
NO_WORKER_FOUND - alluxio.exception.ExceptionMessage
 
NoAuthority - Class in alluxio.uri
A Singleton of NoAuthority, it represents a URI without authority.
NodeInfo - Class in alluxio.util.webui
Class to make referencing worker nodes more intuitive.
NodeInfo(WorkerInfo) - Constructor for class alluxio.util.webui.NodeInfo
Instantiates a new Node info.
NONE - alluxio.client.WriteType
Do not store the data in Alluxio or Under Storage.
NONE - alluxio.file.options.DescendantType
No descendant processing.
NONE - alluxio.security.authorization.Mode.Bits
 
NonUniqueFieldIndex<T,​V> - Class in alluxio.collections
A class representing a non-unique index.
NonUniqueFieldIndex(IndexDefinition<T, V>) - Constructor for class alluxio.collections.NonUniqueFieldIndex
Constructs a new NonUniqueFieldIndex instance.
NOOP - alluxio.master.journal.JournalType
 
noopCloseable(Iterator<? extends T>) - Static method in class alluxio.resource.CloseableIterator
Wraps around an iterator with no resource to close.
noopRecorder() - Static method in class alluxio.recorder.Recorder
Gets a NoopRecorder that does not actually record anything.
NoopRecorder - Class in alluxio.recorder
A Recorder which does nothing.
NoopUserState - Class in alluxio.security.user
A UserState implementation which does nothing.
NoopUserState.Factory - Class in alluxio.security.user
Factory class to create the user state.
normalizePath(String) - Static method in class alluxio.AlluxioURI
Normalize the path component of the AlluxioURI, by replacing all "//" and "\\" with "/", and trimming trailing slash from non-root path (ignoring windows drive).
normalizePath(String, String) - Static method in class alluxio.util.io.PathUtils
Adds a trailing separator if it does not exist in path.
NOSASL - alluxio.security.authentication.AuthType
Authentication is disabled.
not() - Method in enum alluxio.security.authorization.Mode.Bits
 
NOT_INITIALLY_SYNCED - alluxio.wire.SyncPointInfo.SyncStatus
 
NOT_PERSISTED - alluxio.master.file.meta.PersistenceState
 
NOT_READY - alluxio.time.ExponentialTimer.Result
 
NotFoundException - Exception in alluxio.exception.status
Exception indicating that some requested entity (e.g., file or directory) was not found.
NotFoundException(String) - Constructor for exception alluxio.exception.status.NotFoundException
 
NotFoundException(String, Throwable) - Constructor for exception alluxio.exception.status.NotFoundException
 
NotFoundException(Throwable) - Constructor for exception alluxio.exception.status.NotFoundException
 
NotFoundRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that some requested entity (e.g., file or directory) was not found.
NotFoundRuntimeException(String) - Constructor for exception alluxio.exception.runtime.NotFoundRuntimeException
Constructor.
NotFoundRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.NotFoundRuntimeException
Constructor.
NotFoundRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.NotFoundRuntimeException
Constructor.
NOTHING - alluxio.wire.CommandType
No op command.

O

ObjectLowLevelOutputStream - Class in alluxio.underfs
[Experimental] A stream for writing a file into object storage using streaming upload.
ObjectLowLevelOutputStream(String, String, ListeningExecutorService, long, AlluxioConfiguration) - Constructor for class alluxio.underfs.ObjectLowLevelOutputStream
Constructs a new stream for writing a file.
ObjectPermissions(String, String, short) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.ObjectPermissions
Creates a new ObjectPermissions.
ObjectSizeCalculator - Class in alluxio.util
Contains utility methods for calculating the memory usage of objects.
ObjectSizeCalculator(ObjectSizeCalculator) - Constructor for class alluxio.util.ObjectSizeCalculator
Creates an object size calculator based on a previous one.
ObjectSizeCalculator(ObjectSizeCalculator.MemoryLayoutSpecification) - Constructor for class alluxio.util.ObjectSizeCalculator
Creates an object size calculator that can calculate object sizes for a given memoryLayoutSpecification.
ObjectSizeCalculator(ObjectSizeCalculator.MemoryLayoutSpecification, Set<Class<?>>) - Constructor for class alluxio.util.ObjectSizeCalculator
Creates an object size calculator that can calculate object sizes for a given memoryLayoutSpecification.
ObjectSizeCalculator.MemoryLayoutSpecification - Interface in alluxio.util
Describes constant memory overheads for various constructs in a JVM implementation.
ObjectStatus(String) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
 
ObjectStatus(String, String, long, Long) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.ObjectStatus
 
ObjectUnderFileSystem - Class in alluxio.underfs
An object based abstract UnderFileSystem.
ObjectUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration) - Constructor for class alluxio.underfs.ObjectUnderFileSystem
Constructs an ObjectUnderFileSystem.
ObjectUnderFileSystem.DeleteBuffer - Class in alluxio.underfs
Object keys added to a ObjectUnderFileSystem.DeleteBuffer will be deleted in batches.
ObjectUnderFileSystem.ObjectListingChunk - Interface in alluxio.underfs
A chunk of listing results.
ObjectUnderFileSystem.ObjectPermissions - Class in alluxio.underfs
Permissions in object UFS.
ObjectUnderFileSystem.ObjectStatus - Class in alluxio.underfs
Information about a single object in object UFS.
ObjectUnderFileSystem.ObjectStoreOperation<T> - Interface in alluxio.underfs
Represents an object store operation.
ObjectUnderFileSystem.OperationBuffer<T> - Class in alluxio.underfs
Operations added to this buffer are performed concurrently.
ObjectUnderFileSystem.OperationBuffer.OperationThread - Class in alluxio.underfs
Thread class to operate on a batch of objects.
ObjectUnderFileSystem.RenameBuffer - Class in alluxio.underfs
File paths added to a ObjectUnderFileSystem.RenameBuffer will be renamed concurrently.
OBS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
OBS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
 
OBS_BUCKET_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
OBS_BUCKET_TYPE - Static variable in class alluxio.conf.PropertyKey
 
OBS_ENDPOINT - Static variable in class alluxio.conf.PropertyKey.Name
 
OBS_ENDPOINT - Static variable in class alluxio.conf.PropertyKey
 
OBS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
OBS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
 
obtrudeException(Throwable) - Method in class alluxio.concurrent.jsr.CompletableFuture
Forcibly causes subsequent invocations of method CompletableFuture.get() and related methods to throw the given exception, whether or not already completed.
obtrudeValue(T) - Method in class alluxio.concurrent.jsr.CompletableFuture
Forcibly sets or resets the value subsequently returned by method CompletableFuture.get() and related methods, whether or not already completed.
of(long) - Static method in class alluxio.file.FileId
Gets a long-based file ID.
of(String) - Static method in class alluxio.file.FileId
Gets a String-based file ID.
offer(T) - Method in class alluxio.util.executor.UniqueBlockingQueue
 
offer(T, long, TimeUnit) - Method in class alluxio.util.executor.UniqueBlockingQueue
 
offerBuffer(DataBuffer, T) - Method in class alluxio.grpc.DataMessageMarshaller
 
offerBuffer(TBuf, TMesg) - Method in interface alluxio.grpc.BufferRepository
Stores a buffer in the repository.
offset() - Method in class alluxio.file.ByteArrayTargetBuffer
 
offset() - Method in class alluxio.file.ByteBufferTargetBuffer
 
offset() - Method in class alluxio.file.NettyBufTargetBuffer
 
offset() - Method in interface alluxio.file.ReadTargetBuffer
 
offset(int) - Method in class alluxio.file.ByteArrayTargetBuffer
 
offset(int) - Method in class alluxio.file.ByteBufferTargetBuffer
 
offset(int) - Method in class alluxio.file.NettyBufTargetBuffer
 
offset(int) - Method in interface alluxio.file.ReadTargetBuffer
Sets the new offset in the buffer.
ofNonUnique(Function<T, V>) - Static method in class alluxio.collections.IndexDefinition
Creates a new, non-unique index definition.
ofOrdinal(int) - Static method in enum alluxio.security.authorization.AclAction
 
ofUnique(Function<T, V>) - Static method in class alluxio.collections.IndexDefinition
Creates a new, unique index definition.
OK - alluxio.cli.ValidationUtils.State
 
onAbortBlock(long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when aborting a temporary block.
onAccessBlock(long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when accessing a block.
onAccessBlock(long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when accessing a block.
onBlockLost(long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when a block is lost.
ONCE - alluxio.wire.LoadMetadataType
Loads metadata only at the first time of listing status on a directory.
onCommitBlock(long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when committing a temporary block to a BlockStoreLocation.
onCompleted() - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
 
onCompleted() - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
 
onCompletion(CountedCompleter<?>) - Method in class alluxio.concurrent.jsr.CountedCompleter
Performs an action when method CountedCompleter.tryComplete() is invoked and the pending count is zero, or when the unconditional method CountedCompleter.complete(T) is invoked.
ONE - alluxio.file.options.DescendantType
Process only 1 level of children.
onError(Throwable) - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
 
onError(Throwable) - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
 
onError(Throwable) - Method in class alluxio.thread.AutopsyThread
Handles the uncaught error on thread crashing.
onExceptionalCompletion(Throwable, CountedCompleter<?>) - Method in class alluxio.concurrent.jsr.CountedCompleter
Performs an action when method ForkJoinTask.completeExceptionally(Throwable) is invoked or method CountedCompleter.compute() throws an exception, and this task has not already otherwise completed normally.
onMoveBlockByClient(long, BlockStoreLocation, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when moving a block by a client from a BlockStoreLocation to another.
onMoveBlockByWorker(long, BlockStoreLocation, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when moving a block by a worker from a BlockStoreLocation to another.
onNext(SaslMessage) - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
 
onNext(SaslMessage) - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
 
onRemoveBlock(long, BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when removing an existing block.
onRemoveBlockByClient(long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when removing an existing block.
onRemoveBlockByWorker(long) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when removing an existing block by worker.
onStart() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
Initializes internal state after construction but before processing any tasks.
onStorageLost(BlockStoreLocation) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when a storage dir is lost.
onStorageLost(String, String) - Method in interface alluxio.worker.block.BlockStoreEventListener
Actions when a storage dir is lost.
onTermination(Throwable) - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
Performs cleanup associated with termination of this worker thread.
open(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
open(String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
open(String) - Method in interface alluxio.underfs.UnderFileSystem
Opens an InputStream for a file in under filesystem at the indicated path.
open(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
open(String, OpenOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
open(String, OpenOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
open(String, OpenOptions) - Method in interface alluxio.underfs.UnderFileSystem
Opens an InputStream for a file in under filesystem at the indicated path.
open(String, OpenOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
OPEN - alluxio.metrics.MetricInfo.UfsOps
 
OpenDirectoryException - Exception in alluxio.exception
The exception thrown when trying to call openFile on a directory.
OpenDirectoryException(AlluxioURI) - Constructor for exception alluxio.exception.OpenDirectoryException
Constructs a new exception stating that the given directory cannot be opened for reading.
OpenDirectoryException(String) - Constructor for exception alluxio.exception.OpenDirectoryException
Constructs a new exception with the specified detail message.
openExistingFile(String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
openExistingFile(String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
openExistingFile(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
openExistingFile(String) - Method in interface alluxio.underfs.UnderFileSystem
Opens an InputStream for a file in under filesystem at the indicated path.
openExistingFile(String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
openExistingFile(String, OpenOptions) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
openExistingFile(String, OpenOptions) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
openExistingFile(String, OpenOptions) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
openExistingFile(String, OpenOptions) - Method in interface alluxio.underfs.UnderFileSystem
Opens an InputStream for a file in under filesystem at the indicated path.
openExistingFile(String, OpenOptions) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
openObject(String, OpenOptions, RetryPolicy) - Method in class alluxio.underfs.ObjectUnderFileSystem
Internal function to open an input stream to an object.
OpenOptions - Class in alluxio.underfs.options
Method options for file locations in UnderFileSystem.
openPositionRead(String, long) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
openPositionRead(String, long) - Method in interface alluxio.underfs.UnderFileSystem
Opens a file for position read.
openPositionRead(String, long) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
openUfsBlock(long, long, Protocol.OpenUfsBlockOptions) - Method in interface alluxio.worker.block.BlockWorker
Opens a UFS block.
operate(List<Pair<String, String>>) - Method in class alluxio.underfs.ObjectUnderFileSystem.RenameBuffer
 
operate(List<String>) - Method in class alluxio.underfs.ObjectUnderFileSystem.DeleteBuffer
 
operate(List<T>) - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Operate on a list of input type ObjectUnderFileSystem.OperationBuffer.
OperationBuffer() - Constructor for class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Construct a new ObjectUnderFileSystem.OperationBuffer instance.
OperationId - Class in alluxio.wire
Used as an unique ID wrapper.
OperationId(Long, Long) - Constructor for class alluxio.wire.OperationId
Constructs and initializes a 128 bit OperationId.
OperationId(UUID) - Constructor for class alluxio.wire.OperationId
Constructs and initializes a 128 bit OperationId from an UUID.
OperationSystemGaugeSet - Class in alluxio.metrics
A set of counters for the os metric.
OperationSystemGaugeSet() - Constructor for class alluxio.metrics.OperationSystemGaugeSet
 
OperationThread(List<T>) - Constructor for class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer.OperationThread
Operate on a batch of inputs.
or(Mode.Bits) - Method in enum alluxio.security.authorization.Mode.Bits
 
orTimeout(long, TimeUnit) - Method in class alluxio.concurrent.jsr.CompletableFuture
Exceptionally completes this CompletableFuture with a TimeoutException if not otherwise completed before the given timeout.
OS_LOGIN_MODULE_NAME - Static variable in class alluxio.security.login.LoginModuleConfigurationUtils
Login module according to different OS type.
OS_NAME - Static variable in class alluxio.util.OSUtils
The OS name.
OS_PRINCIPAL_CLASS_NAME - Static variable in class alluxio.security.login.LoginModuleConfigurationUtils
Class name of Principal according to different OS type.
OSS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
OSS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
 
OSS_ENDPOINT_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
OSS_ENDPOINT_KEY - Static variable in class alluxio.conf.PropertyKey
 
OSS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
OSS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
 
OSUtils - Class in alluxio.util
OS related utility functions.
OTHER - alluxio.security.authorization.AclEntryType
 
OTHER_COMPONENT - Static variable in enum alluxio.security.authorization.AclEntryType
 
outList(String) - Method in class alluxio.collections.PrefixList
Checks whether a prefix of path is not in the prefix list.
OutOfRangeException - Exception in alluxio.exception.status
Exception indicating that and operation was attempted past the valid range.
OutOfRangeException(String) - Constructor for exception alluxio.exception.status.OutOfRangeException
 
OutOfRangeException(String, Throwable) - Constructor for exception alluxio.exception.status.OutOfRangeException
 
OutOfRangeException(Throwable) - Constructor for exception alluxio.exception.status.OutOfRangeException
 
OutOfRangeRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that and operation was attempted past the valid range.
OutOfRangeRuntimeException(String) - Constructor for exception alluxio.exception.runtime.OutOfRangeRuntimeException
Constructor.
OVERRIDDEN_METHOD_DESCRIPTOR - Static variable in class alluxio.grpc.GrpcSerializationUtils
 
overrideMethods(ServerServiceDefinition, Map<MethodDescriptor, MethodDescriptor>) - Static method in class alluxio.grpc.GrpcSerializationUtils
Creates a service definition that uses custom marshallers.
OWNER - alluxio.underfs.Fingerprint.Tag
 
OWNER_FIELD - Static variable in class alluxio.security.authorization.AccessControlList
Keys representing owning user and group for proto ser/de.
OWNING_GROUP - alluxio.security.authorization.AclEntryType
 
OWNING_GROUP_FIELD - Static variable in class alluxio.security.authorization.AccessControlList
 
OWNING_GROUP_KEY - Static variable in class alluxio.security.authorization.AccessControlList
 
OWNING_USER - alluxio.security.authorization.AclEntryType
 
OWNING_USER_KEY - Static variable in class alluxio.security.authorization.AccessControlList
 

P

PAGE - alluxio.worker.block.BlockStoreType
The block is written to the page cache which is implemented in LocalCacheManager.
PageNotFoundException - Exception in alluxio.exception
An exception that should be thrown when a page is not found in store.
PageNotFoundException(String) - Constructor for exception alluxio.exception.PageNotFoundException
Constructs a new exception with the specified detail message.
PageNotFoundException(String, Throwable) - Constructor for exception alluxio.exception.PageNotFoundException
Constructs a new exception with the specified detail message and cause.
PageStoreType - Enum in alluxio.client.file.cache.store
This represents the different page store implementations that can be instantiated.
Pair<T1,​T2> - Class in alluxio.collections
A pair representation defined by two elements (of type First and type Second).
Pair() - Constructor for class alluxio.collections.Pair
Default constructor for deserialization.
Pair(T1, T2) - Constructor for class alluxio.collections.Pair
Constructs and initializes a Pair specified by the two input elements.
parallelStream() - Method in class alluxio.collections.DelegatingSet
 
parametersToString(Object...) - Static method in class alluxio.util.FormatUtils
Parses a list of Objects into a String.
parent() - Method in enum alluxio.client.quota.CacheScope.Level
 
parent() - Method in class alluxio.client.quota.CacheScope
 
PARENT_CREATION_FAILED - alluxio.exception.ExceptionMessage
 
parentExists(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Treating the object store as a file system, checks if the parent directory exists.
parse(InputStream) - Method in class alluxio.grpc.DataMessageMarshaller
 
parse(String) - Static method in class alluxio.security.authorization.ModeParser
Parses the given value as a mode.
parse(String) - Static method in class alluxio.underfs.Fingerprint
Parses the input string and returns the fingerprint object.
parseAndValidateArgs(String...) - Method in interface alluxio.cli.Command
Parses and validates the arguments.
parseAsList(String, String) - Static method in class alluxio.util.ConfigurationUtils
Returns the input string as a list, splitting on a specified delimiter.
parseFrom(byte[], ProtoMessage) - Static method in class alluxio.util.proto.ProtoMessage
Parses proto message from bytes given a prototype.
parseInetSocketAddress(String) - Static method in class alluxio.util.network.NetworkAddressUtils
Parses InetSocketAddress from a String.
parseInetSocketAddresses(List<String>) - Static method in class alluxio.util.ConfigurationUtils
 
parseMajorVersion(String) - Static method in class alluxio.util.CommonUtils
 
parseMountInfo(String) - Static method in class alluxio.util.ShellUtils
 
parseQueryString(String) - Static method in class alluxio.util.URIUtils
Parses the given query string, and returns a map of the query parameters.
parseSpaceSize(String) - Static method in class alluxio.util.FormatUtils
Parses a String size to Bytes.
parseTimeSize(String) - Static method in class alluxio.util.FormatUtils
Parses a String size to Milliseconds.
parseValue(String) - Method in class alluxio.conf.PropertyKey
Parses value from string.
partition(List<T>, int) - Static method in class alluxio.util.CommonUtils
Partitions a list into numLists many lists each with around list.size() / numLists elements.
PARTITION - alluxio.client.quota.CacheScope.Level
 
PATH_DEFAULT - alluxio.conf.Source.Type
The property value is specified as path level defaults through command line.
PATH_DEFAULT - Static variable in class alluxio.conf.Source
 
PATH_DOES_NOT_EXIST - alluxio.exception.ExceptionMessage
 
PATH_DOES_NOT_EXIST_PARTIAL_LISTING - alluxio.exception.ExceptionMessage
 
PATH_INVALID - alluxio.exception.ExceptionMessage
 
PATH_MUST_BE_FILE - alluxio.exception.ExceptionMessage
 
PATH_MUST_HAVE_VALID_PARENT - alluxio.exception.ExceptionMessage
 
PATH_SEPARATOR - Static variable in class alluxio.underfs.ObjectUnderFileSystem
Value used to indicate nested structure.
PATH_SEPARATOR_CHAR - Static variable in class alluxio.underfs.ObjectUnderFileSystem
Value used to indicate nested structure.
PATH_STRING_COMPARE - Static variable in class alluxio.util.webui.UIFileInfo
Provides ordering of UIFileInfo based off a string comparison of the absolute paths.
PathConfiguration - Interface in alluxio.conf.path
Path level configuration.
PathMatcher - Interface in alluxio.conf.path
Matches a path against a set of path patterns.
PathUtils - Class in alluxio.util.io
Utilities related to both Alluxio paths like AlluxioURI and local file paths.
PB - Static variable in class alluxio.Constants
 
peek() - Method in class alluxio.util.executor.UniqueBlockingQueue
 
peekNextLocalTask() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Returns, but does not unschedule or execute, a task queued by the current thread but not yet executed, if one is immediately available.
PERMISSION_DENIED - alluxio.exception.ExceptionMessage
 
PermissionDeniedException - Exception in alluxio.exception.status
Exception indicating that the caller does not have permission to execute the specified operation.
PermissionDeniedException(String) - Constructor for exception alluxio.exception.status.PermissionDeniedException
 
PermissionDeniedException(String, Throwable) - Constructor for exception alluxio.exception.status.PermissionDeniedException
 
PermissionDeniedException(Throwable) - Constructor for exception alluxio.exception.status.PermissionDeniedException
 
PermissionDeniedRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that the caller does not have permission to execute the specified operation.
PermissionDeniedRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.PermissionDeniedRuntimeException
Constructor.
permitKeepAlive(long, TimeUnit) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the high-bar for client-side keep-alive frequency.
PERSIST - alluxio.wire.CommandType
Ask worker to persist a file.
PersistCommandOptions - Class in alluxio.wire
Class to represent a persist options.
PersistCommandOptions(List<PersistFile>) - Constructor for class alluxio.wire.PersistCommandOptions
Creates a new instance of PersistCommandOptions.
PERSISTED - alluxio.master.file.meta.PersistenceState
 
PERSISTENCE_INVALID_JOB_ID - Static variable in class alluxio.Constants
 
PERSISTENCE_INVALID_UFS_PATH - Static variable in class alluxio.Constants
 
PersistenceState - Enum in alluxio.master.file.meta
The persistence state of a file in the under-storage system.
PersistFile - Class in alluxio.wire
Class to represent a file persist info.
PersistFile(long, List<Long>) - Constructor for class alluxio.wire.PersistFile
Creates a new instance for persist file.
pinBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Pins the block indicating subsequent access.
pingService(InetSocketAddress, ServiceType, AlluxioConfiguration, UserState) - Static method in class alluxio.util.network.NetworkAddressUtils
Test if the input address is serving an Alluxio service.
PlainSaslClientCallbackHandler - Class in alluxio.security.authentication.plain
A client side callback to put application provided username/password into SASL transport.
PlainSaslClientCallbackHandler(String, String) - Constructor for class alluxio.security.authentication.plain.PlainSaslClientCallbackHandler
Constructs a new client side callback.
PlainSaslServer - Class in alluxio.security.authentication.plain
This class provides PLAIN SASL authentication.
PlainSaslServer.Factory - Class in alluxio.security.authentication.plain
This class is used to create an instances of PlainSaslServer.
PlainSaslServerCallbackHandler - Class in alluxio.security.authentication.plain
A callback that is used by the SASL mechanisms to get further information to complete the authentication.
PlainSaslServerCallbackHandler(AuthenticationProvider, ImpersonationAuthenticator) - Constructor for class alluxio.security.authentication.plain.PlainSaslServerCallbackHandler
Constructs a new callback handler.
PlainSaslServerProvider - Class in alluxio.security.authentication.plain
The Java SunSASL provider supports CRAM-MD5, DIGEST-MD5 and GSSAPI mechanisms on the server side.
PlainSaslServerProvider() - Constructor for class alluxio.security.authentication.plain.PlainSaslServerProvider
Constructs a new provider for the SASL server when using the PLAIN mechanism.
PLUGIN - alluxio.metrics.MetricsSystem.InstanceType
 
PLUGIN - alluxio.util.CommonUtils.ProcessType
 
poll() - Method in class alluxio.util.executor.UniqueBlockingQueue
 
poll(long, TimeUnit) - Method in class alluxio.util.executor.UniqueBlockingQueue
 
pollBuffer(T) - Method in class alluxio.grpc.DataMessageMarshaller
 
pollBuffer(TMesg) - Method in interface alluxio.grpc.BufferRepository
Retrieves and removes a buffer from the store.
PollingMasterInquireClient - Class in alluxio.master
PollingMasterInquireClient finds the address of the primary master by polling a list of master addresses to see if their RPC servers are serving.
PollingMasterInquireClient(List<InetSocketAddress>, AlluxioConfiguration, UserState, ServiceType) - Constructor for class alluxio.master.PollingMasterInquireClient
 
PollingMasterInquireClient(List<InetSocketAddress>, Supplier<RetryPolicy>, AlluxioConfiguration, ServiceType) - Constructor for class alluxio.master.PollingMasterInquireClient
 
PollingMasterInquireClient(List<InetSocketAddress>, Supplier<RetryPolicy>, AlluxioConfiguration, UserState, ServiceType) - Constructor for class alluxio.master.PollingMasterInquireClient
 
PollingMasterInquireClient.MultiMasterConnectDetails - Class in alluxio.master
Details used to connect to the leader Alluxio master when there are multiple potential leaders.
pollNextLocalTask() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
Unschedules and returns, without executing, the next task queued by the current thread but not yet executed, if the current thread is operating in a ForkJoinPool.
pollSubmission() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Removes and returns the next unexecuted submission if one is available.
pollSubmission() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
If the current thread is operating in a ForkJoinPool, unschedules and returns, without executing, a task externally submitted to the pool, if one is available.
pollTask() - Static method in class alluxio.concurrent.jsr.ForkJoinTask
If the current thread is operating in a ForkJoinPool, unschedules and returns, without executing, the next task queued by the current thread but not yet executed, if one is available, or if not available, a task that was forked by some other thread, if available.
Pool<T> - Interface in alluxio.resource
Interface representing a pool of resources to be temporarily used and returned.
PooledDirectNioByteBuf - Class in alluxio.network.protocol.databuffer
Pooled direct NIO byte buffer allocated from NioDirectBufferPool wrapped in Netty ByteBuf.
PooledResource<T> - Class in alluxio.resource
A pooled resource that was acquired from a Pool, and will be released back to the pool when it's closed.
PooledResource(T, Pool<T>) - Constructor for class alluxio.resource.PooledResource
Creates a new pooled resource with the pool from which it was acquired.
pop() - Method in class alluxio.util.executor.ControllableQueue
 
Positioned - Interface in alluxio
An interface for an object which tracks and can report its current position (for example a stream).
PositionReader - Interface in alluxio
Position read interface.
PositionReaderTest - Class in alluxio
A position reader test to test position read from the given reader.
PositionReaderTest(PositionReader, int) - Constructor for class alluxio.PositionReaderTest
 
post(String, Integer) - Static method in class alluxio.util.network.HttpUtils
Uses the post method to send a url with arguments by http, this method can call RESTful Api.
post(String, String, Integer, HttpUtils.IProcessInputStream) - Static method in class alluxio.util.network.HttpUtils
Uses the post method to send a url with arguments by http, this method can call RESTful Api.
PreconditionMessage - Enum in alluxio.exception
Precondition messages used across Alluxio.
PREFIX_DOES_NOT_MATCH_PATH - alluxio.exception.ExceptionMessage
 
PrefixList - Class in alluxio.collections
Prefix list is used to do file filtering.
PrefixList(String, String) - Constructor for class alluxio.collections.PrefixList
Prefix list is used to do file filtering.
PrefixList(List<String>) - Constructor for class alluxio.collections.PrefixList
Prefix list is used to do file filtering.
PrefixPathConfiguration - Class in alluxio.conf.path
Configurations for path prefixes.
PrefixPathConfiguration(Map<String, AlluxioConfiguration>) - Constructor for class alluxio.conf.path.PrefixPathConfiguration
Constructs a new path level configuration.
PrefixPathMatcher - Class in alluxio.conf.path
A PathMatcher to match a path against a set of paths.
PrefixPathMatcher(Set<String>) - Constructor for class alluxio.conf.path.PrefixPathMatcher
Builds internal trie based on paths.
primaryMaster() - Static method in class alluxio.master.selectionpolicy.MasterSelectionPolicy.Factory
Creates a MasterSelectionPolicy that selects the primary master to connect.
printTestStatus(boolean) - Static method in class alluxio.cli.RunTestUtils
Prints information of the test result.
printTestStatus(boolean, PrintStream) - Static method in class alluxio.cli.RunTestUtils
Prints information of the test result to redirected streams.
printThreadInfo(PrintStream, String) - Static method in class alluxio.util.ThreadUtils
Prints the information and stack traces of all threads.
printUsage() - Method in class alluxio.cli.AbstractShell
Prints usage for all commands.
process(InputStream) - Method in interface alluxio.util.network.HttpUtils.IProcessInputStream
 
PROCESS - alluxio.metrics.MetricsSystem.InstanceType
 
PROCESS_POOL_DIRECT_MEM_USED - Static variable in class alluxio.metrics.MetricKey
 
PROCESS_TYPE - Static variable in class alluxio.util.CommonUtils
Represents the type of Alluxio process running in this JVM.
PROCESSOR_BIT - Static variable in class alluxio.util.OSUtils
The processor bit.
ProjectConstants - Class in alluxio
Project constants from compilation time by maven.
PROMOTE - alluxio.client.AlluxioStorageType
Same as AlluxioStorageType.STORE for writes.
propagateCompletion() - Method in class alluxio.concurrent.jsr.CountedCompleter
Equivalent to CountedCompleter.tryComplete() but does not invoke CountedCompleter.onCompletion(CountedCompleter) along the completion path: If the pending count is nonzero, decrements the count; otherwise, similarly tries to complete this task's completer, if one exists, else marks this task as complete.
Property - Class in alluxio.wire
Wire representation of a configuration property.
Property(String, Object, Source) - Constructor for class alluxio.wire.Property
Creates a new property.
PropertyKey - Class in alluxio.conf
Configuration property keys.
PropertyKey.Builder - Class in alluxio.conf
Builder to create PropertyKey instances.
PropertyKey.ConsistencyCheckLevel - Enum in alluxio.conf
The consistency check level to apply to a certain property key.
PropertyKey.DisplayType - Enum in alluxio.conf
Indicates how the property value should be displayed.
PropertyKey.Name - Class in alluxio.conf
A nested class to hold named string constants for their corresponding properties.
PropertyKey.PropertyType - Enum in alluxio.conf
Indicates property type.
PropertyKey.Template - Enum in alluxio.conf
A set of templates to generate the names of parameterized properties given different parameters.
ProtoMessage - Class in alluxio.util.proto
A simple wrapper around the MessageLite class in Protobuf for a few messages defined and generated in Alluxio.
ProtoMessage(Protocol.AsyncCacheRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.Heartbeat) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockCloseRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockCompleteRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockCreateRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockCreateResponse) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockOpenRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.LocalBlockOpenResponse) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.ReadRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.ReadResponse) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.Response) - Constructor for class alluxio.util.proto.ProtoMessage
 
ProtoMessage(Protocol.WriteRequest) - Constructor for class alluxio.util.proto.ProtoMessage
 
protoToShort(PMode) - Static method in class alluxio.util.ModeUtils
Used to get short value of a proto PMode.
ProtoUtils - Class in alluxio.util.proto
Protobuf related utils.
PROXY - alluxio.metrics.MetricsSystem.InstanceType
 
PROXY - alluxio.util.CommonUtils.ProcessType
 
PROXY_AUDIT_LOG_ENTRIES_SIZE - Static variable in class alluxio.metrics.MetricKey
 
PROXY_AUDIT_LOGGING_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_AUDIT_LOGGING_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
PROXY_CHECK_UPLOADID_STATUS_LATENCY - Static variable in class alluxio.metrics.MetricKey
 
PROXY_CLEANUP_MULTIPART_UPLOAD_LATENCY - Static variable in class alluxio.metrics.MetricKey
 
PROXY_CLEANUP_TEMP_MULTIPART_UPLOAD_OBJ_LATENCY - Static variable in class alluxio.metrics.MetricKey
 
PROXY_COMPLETE_MP_UPLOAD_MERGE_LATENCY - Static variable in class alluxio.metrics.MetricKey
 
PROXY_S3_BUCKET_NAMING_RESTRICTIONS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_BUCKET_NAMING_RESTRICTIONS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_KEEPALIVE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_KEEPALIVE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_KEEPALIVE_TIME_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_KEEPALIVE_TIME_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_MIN_PART_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_MIN_PART_SIZE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_COMPLETE_MULTIPART_UPLOAD_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_DELETE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_DELETE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_HEADER_METADATA_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_METADATA_HEADER_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_RETRY_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_RETRY_COUNT - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_RETRY_DELAY - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_RETRY_DELAY - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_MULTIPART_UPLOAD_CLEANER_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_TAGGING_RESTRICTIONS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_TAGGING_RESTRICTIONS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
PROXY_S3_WRITE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_S3_WRITE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
PROXY_STREAM_CACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_STREAM_CACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
PROXY_WEB - alluxio.util.network.NetworkAddressUtils.ServiceType
Proxy web service (Jetty).
PROXY_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
PROXY_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
PROXY_WEB_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
PROXY_WEB_PORT - Static variable in class alluxio.conf.PropertyKey
 
PublicApi - Annotation Type in alluxio.annotation
A public API annotation for annotating classes and interfaces that are externally facing.
put(PropertyKey, Object, Source) - Method in class alluxio.conf.AlluxioProperties
Puts the key value pair specified by users.
put(K, V) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
put(T) - Method in class alluxio.util.executor.UniqueBlockingQueue
 
putAll(Map<? extends K, ? extends V>) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
putIfAbsent(K, V) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
putIntByteBuffer(ByteBuffer, int) - Static method in class alluxio.util.io.BufferUtils
Puts a byte (the first byte of an integer) into a ByteBuffer.
putObject(String, File, String) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
putTag(Fingerprint.Tag, String) - Method in class alluxio.underfs.Fingerprint
Updates a specific tag in the fingerprint.

Q

QUERY_KEY_VALUE_SEPARATOR - Static variable in class alluxio.util.URIUtils
 
QUERY_SEPARATOR - Static variable in class alluxio.util.URIUtils
 
queryGrpcServerAddress() - Method in class alluxio.AbstractClient
AbstractClient works with Grpc Servers.
queryGrpcServerAddress() - Method in class alluxio.AbstractMasterClient
 
quietlyComplete() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Completes this task normally without setting a value.
quietlyCompleteRoot() - Method in class alluxio.concurrent.jsr.CountedCompleter
Equivalent to getRoot().quietlyComplete().
quietlyInvoke() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Commences performing this task and awaits its completion if necessary, without returning its result or throwing its exception.
quietlyJoin() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Joins this task, without returning its result or throwing its exception.

R

RAFT_JOURNAL_SERVICE_NAME - Static variable in class alluxio.Constants
 
RAFT_JOURNAL_SERVICE_VERSION - Static variable in class alluxio.Constants
 
randomAlphaNumString(int) - Static method in class alluxio.util.CommonUtils
Generates a random alphanumeric string of the given length.
randomBytes(int) - Static method in class alluxio.util.CommonUtils
Generates a random byte array of the given length.
read() - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
read(byte[]) - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
read(byte[], int, int) - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
read(long, byte[], int) - Method in interface alluxio.PositionReader
 
read(long, byte[], int, int) - Method in interface alluxio.PositionReader
 
read(long, long) - Method in class alluxio.worker.block.io.BlockReader
Reads data from the block.
read(long, long) - Method in class alluxio.worker.block.io.DelegatingBlockReader
 
read(long, long) - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
read(long, ReadTargetBuffer, int) - Method in interface alluxio.PositionReader
 
read(long, ByteBuf, int) - Method in interface alluxio.PositionReader
 
read(long, ByteBuffer, int) - Method in interface alluxio.PositionReader
 
read(ByteBuffer) - Method in class alluxio.worker.block.io.BlockReadableChannel
 
READ - alluxio.concurrent.LockMode
 
READ - alluxio.security.authorization.AclAction
 
READ - alluxio.security.authorization.Mode.Bits
 
READ_CLOSED_STREAM - alluxio.exception.ExceptionMessage
 
READ_EXECUTE - alluxio.security.authorization.Mode.Bits
 
READ_ONLY - alluxio.underfs.UfsMode
 
READ_WRITE - alluxio.security.authorization.Mode.Bits
 
READ_WRITE - alluxio.underfs.UfsMode
 
readableBytes() - Method in class alluxio.grpc.ReadableDataBuffer
 
readableBytes() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
 
readableBytes() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
readableBytes() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
readableBytes() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
ReadableDataBuffer - Class in alluxio.grpc
Class for making wrapping ReadableBuffer as DataBuffer.
ReadableDataBuffer(ReadableBuffer) - Constructor for class alluxio.grpc.ReadableDataBuffer
Creates DataBuffer for reading.
readBlock(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Gets the path to the block file in local storage.
readBlockRemote(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Gets the block reader for the block.
readByte(byte[], int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific byte value from the input byte array at the given offset.
readByte(ByteBuffer, int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific byte value from the input byte buffer at the given offset.
readBytes(byte[], int, int) - Method in class alluxio.grpc.ReadableDataBuffer
 
readBytes(byte[], int, int) - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Transfers this buffer's data to the specified destination starting at the current readerIndex and increases the readerIndex by the number of the transferred bytes (= length).
readBytes(byte[], int, int) - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
readBytes(byte[], int, int) - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
readBytes(byte[], int, int) - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
readBytes(OutputStream, int) - Method in class alluxio.grpc.ReadableDataBuffer
 
readBytes(OutputStream, int) - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Transfers this buffer's data to the given stream.
readBytes(OutputStream, int) - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
readBytes(OutputStream, int) - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
readBytes(OutputStream, int) - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
readBytes(ByteBuffer) - Method in class alluxio.grpc.ReadableDataBuffer
 
readBytes(ByteBuffer) - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Transfers this buffer's data to the given ByteBuffer.
readBytes(ByteBuffer) - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
readBytes(ByteBuffer) - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
 
readBytes(ByteBuffer) - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
READER - alluxio.worker.block.io.BlockClient.Type
 
readFromFile(RandomAccessFile, int) - Method in class alluxio.file.ByteArrayTargetBuffer
 
readFromFile(RandomAccessFile, int) - Method in class alluxio.file.ByteBufferTargetBuffer
 
readFromFile(RandomAccessFile, int) - Method in class alluxio.file.NettyBufTargetBuffer
 
readFromFile(RandomAccessFile, int) - Method in interface alluxio.file.ReadTargetBuffer
 
readFromInputStream(InputStream, int) - Method in class alluxio.file.ByteArrayTargetBuffer
 
readFromInputStream(InputStream, int) - Method in class alluxio.file.ByteBufferTargetBuffer
 
readFromInputStream(InputStream, int) - Method in class alluxio.file.NettyBufTargetBuffer
 
readFromInputStream(InputStream, int) - Method in interface alluxio.file.ReadTargetBuffer
 
readInt(byte[], int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific integer byte value (4 bytes) from the input byte array at the given offset.
readInt(ByteBuffer, int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific integer byte value (4 bytes) from the input byte buffer at the given offset.
readInternal(long, ReadTargetBuffer, int) - Method in interface alluxio.PositionReader
 
readLock() - Method in class alluxio.concurrent.ClientRWLock
 
readLong(byte[], int) - Static method in class alluxio.master.metastore.rocks.RocksUtils
 
readLong(byte[], int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific long byte value (8 bytes) from the input byte array at the given offset.
readNodeList(String, String) - Static method in class alluxio.cli.CommandUtils
Reads a list of nodes from given file name ignoring comments and empty lines.
readRawVarint32(int, InputStream) - Static method in class alluxio.util.proto.ProtoUtils
A wrapper of CodedInputStream.readRawVarint32(InputStream).
readRawVarint32(InputStream) - Static method in class alluxio.util.proto.ProtoUtils
A wrapper of CodedInputStream.readRawVarint32(InputStream).
ReadResponseMarshaller - Class in alluxio.grpc
Marshaller for ReadResponse.
ReadResponseMarshaller() - Constructor for class alluxio.grpc.ReadResponseMarshaller
readShort(byte[], int) - Static method in class alluxio.util.io.ByteIOUtils
Reads a specific short byte value (2 bytes) from the input byte array at the given offset.
ReadTargetBuffer - Interface in alluxio.file
TargetBuffer for zero-copy read from page store.
ReadType - Enum in alluxio.client
Convenience modes for commonly used read types.
readUfsBlock(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Gets a block reader to read a UFS block.
READY - alluxio.time.ExponentialTimer.Result
 
Reconfigurable - Interface in alluxio.conf
Reconfigurable listener.
ReconfigurableRegistry - Class in alluxio.conf
Registry of all reconfigurable listeners.
record(double) - Method in class alluxio.metrics.TimeSeries
Record a value at the current time.
record(String) - Method in class alluxio.recorder.NoopRecorder
 
record(String) - Method in class alluxio.recorder.Recorder
Records a message.
record(String, Object...) - Method in class alluxio.recorder.NoopRecorder
 
record(String, Object...) - Method in class alluxio.recorder.Recorder
Records a message with a format template and arguments.
Recorder - Class in alluxio.recorder
A tool for recording information, which can be used to record the process of execution.
Recorder() - Constructor for class alluxio.recorder.Recorder
Constructs a new instance.
recursiveListLocalDir(File) - Static method in class alluxio.util.CommonUtils
Recursively lists a local dir and all its subdirs and return all the files.
RefCountLockResource - Class in alluxio.resource
Reference counted Lock resource, automatically unlocks and decrements the reference count.
RefCountLockResource(ReentrantReadWriteLock, LockMode, boolean, AtomicInteger, boolean) - Constructor for class alluxio.resource.RefCountLockResource
Creates a new instance of LockResource using the given lock and reference counter.
refresh() - Method in class alluxio.cli.ValidationToolRegistry
Refreshes the registry by service loading classes.
RefreshPolicy - Interface in alluxio.refresh
Policy for determining whether a refresh should be performed.
REGEX_STRING - Static variable in class alluxio.conf.PropertyKey
Regex string to find "${key}" for variable substitution.
RegexMetricFilter - Class in alluxio.metrics.sink
A regex metrics filter.
RegexMetricFilter(Properties) - Constructor for class alluxio.metrics.sink.RegexMetricFilter
Creates a new RegexMetricFilter with a Properties.
register(PropertyKey) - Static method in class alluxio.conf.PropertyKey
Registers the given key to the global key map.
register(Reconfigurable) - Static method in class alluxio.conf.ReconfigurableRegistry
Add a listener.
register(MetricKey) - Static method in class alluxio.metrics.MetricKey
Registers the given key to the global key map.
register(UnderFileSystemFactory) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Registers a new factory.
register(T) - Method in class alluxio.extensions.ExtensionFactoryRegistry
Registers a new factory.
REGISTER - alluxio.wire.CommandType
Ask worker to re-register.
registerAggregatedCachedGaugeIfAbsent(String, Set<MetricKey>, long, TimeUnit) - Static method in class alluxio.metrics.MetricsSystem
Created a gauge that aggregates the value of existing gauges.
registerBlockStoreEventListener(BlockStoreEventListener) - Method in interface alluxio.worker.block.BlockStore
Registers a BlockStoreEventListener to this block store.
registerCachedGaugeIfAbsent(String, Gauge<T>) - Static method in class alluxio.metrics.MetricsSystem
Registers a cached gauge if it has not been registered.
registerCachedGaugeIfAbsent(String, Gauge<T>, long, TimeUnit) - Static method in class alluxio.metrics.MetricsSystem
Registers a cached gauge if it has not been registered.
registerChannel(UUID, AuthenticatedUserInfo, AuthenticatedChannelServerDriver) - Method in interface alluxio.security.authentication.AuthenticationServer
Registers new user against given channel.
registerChannel(UUID, AuthenticatedUserInfo, AuthenticatedChannelServerDriver) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
registerGaugeIfAbsent(String, Gauge<T>) - Static method in class alluxio.metrics.MetricsSystem
Registers a gauge if it has not been registered.
RegisterLease - Class in alluxio.wire
A RegisterLease is what the master uses to control the concurrency of worker registration.
RegisterLease(long) - Constructor for class alluxio.wire.RegisterLease
Constructor.
RegisterLeaseNotFoundException - Exception in alluxio.exception
The exception thrown when the worker attempts to register but there is no lease found.
RegisterLeaseNotFoundException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.RegisterLeaseNotFoundException
Constructs a new exception with the specified exception message and multiple parameters.
RegisterLeaseNotFoundException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.RegisterLeaseNotFoundException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
RegisterLeaseNotFoundException(String) - Constructor for exception alluxio.exception.RegisterLeaseNotFoundException
Constructs a new exception with the specified detail message.
RegisterLeaseNotFoundException(String, Throwable) - Constructor for exception alluxio.exception.RegisterLeaseNotFoundException
Constructs a new exception with the specified detail message and cause.
reinitialize() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Resets the internal bookkeeping state of this task, allowing a subsequent fork.
RejectingServer - Class in alluxio.network
A server which listens on a socket and closes all connections.
RejectingServer(InetSocketAddress) - Constructor for class alluxio.network.RejectingServer
 
release() - Method in class alluxio.concurrent.CountingLatch
Unblocks threads blocked on calling CountingLatch.inc().
release() - Method in class alluxio.grpc.ReadableDataBuffer
 
release() - Method in interface alluxio.network.protocol.databuffer.DataBuffer
Releases the underlying buffer of this DataBuffer if no longer needed.
release() - Method in class alluxio.network.protocol.databuffer.DataFileChannel
 
release() - Method in class alluxio.network.protocol.databuffer.NettyDataBuffer
Release the Netty ByteBuf.
release() - Method in class alluxio.network.protocol.databuffer.NioDataBuffer
 
release(ByteBuffer) - Static method in class alluxio.network.protocol.databuffer.NioDirectBufferPool
 
release(T) - Method in class alluxio.resource.DynamicResourcePool
Releases the resource to the pool.
release(T) - Method in interface alluxio.resource.Pool
Releases the resource to the pool.
release(T) - Method in class alluxio.resource.ResourcePool
Releases an object of type T, this must be called after the thread is done using a resource obtained by acquire.
releaseConnection(GrpcChannelKey) - Method in class alluxio.grpc.GrpcChannelPool
Decreases the ref-count of the ManagedChannel for the given address.
reloadProperties() - Static method in class alluxio.conf.Configuration
Reloads site properties from disk.
relogin() - Method in class alluxio.security.user.BaseUserState
 
relogin() - Method in interface alluxio.security.user.UserState
Attempts to log in again, and returns the new User.
remaining() - Method in class alluxio.file.ByteArrayTargetBuffer
 
remaining() - Method in class alluxio.file.ByteBufferTargetBuffer
 
remaining() - Method in class alluxio.file.NettyBufTargetBuffer
 
remaining() - Method in interface alluxio.file.ReadTargetBuffer
 
remainingCapacity() - Method in class alluxio.util.executor.UniqueBlockingQueue
 
remove() - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Removes the User from the ThreadLocal variable.
remove(int) - Method in class alluxio.collections.UnmodifiableArrayList
 
remove(PropertyKey) - Method in class alluxio.conf.AlluxioProperties
Remove the value set for key.
remove(Long) - Method in class alluxio.util.BucketCounter
remove a number to be counted.
remove(Object) - Method in class alluxio.collections.ConcurrentHashSet
 
remove(Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
remove(Object) - Method in class alluxio.collections.DelegatingSet
 
remove(Object) - Method in class alluxio.collections.IndexedSet
Removes an object from the set.
remove(Object) - Method in class alluxio.collections.UnmodifiableArrayList
 
remove(Object, Object) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
remove(T) - Method in interface alluxio.collections.FieldIndex
Removes the object o from the index.
remove(T) - Method in class alluxio.collections.NonUniqueFieldIndex
 
remove(T) - Method in class alluxio.collections.UniqueFieldIndex
 
remove(T) - Method in class alluxio.util.executor.ControllableQueue
Removes an element.
REMOVE_UNCOMMITTED_BLOCK - alluxio.exception.ExceptionMessage
 
removeAll(Collection<?>) - Method in class alluxio.collections.ConcurrentHashSet
 
removeAll(Collection<?>) - Method in class alluxio.collections.DelegatingSet
 
removeAll(Collection<?>) - Method in class alluxio.collections.UnmodifiableArrayList
 
removeBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Removes an existing block.
removeBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Frees a block from Alluxio managed space.
removeBlockMeta(BlockMeta) - Method in interface alluxio.worker.block.meta.StorageDir
Removes a block from this storage dir.
removeByField(IndexDefinition<T, V>, V) - Method in class alluxio.collections.IndexedSet
Removes the subset of objects with the specified index field value.
removeChild(DirectedAcyclicGraphNode<T>) - Method in class alluxio.collections.DirectedAcyclicGraphNode
Removes a child node from the node.
RemovedKey - Class in alluxio.conf
This class contains old PropertyKeys which have been removed from use This class is used to track keys which were deprecated in previous versions and subsequently removed in a future version.
removeEntry(AclEntry) - Method in class alluxio.security.authorization.AccessControlList
Removes the specified entry.
removeEntry(AclEntry) - Method in class alluxio.security.authorization.DefaultAccessControlList
Removes the specified entry.
removeEntry(AclEntry) - Method in class alluxio.security.authorization.ExtendedACLEntries
Removes the specified entry.
removeExtendedEntries() - Method in class alluxio.security.authorization.AccessControlList
Removes all of the exnteded entries.
removeIf(Predicate<? super T>) - Method in class alluxio.collections.DelegatingSet
 
removeInaccessibleStorage() - Method in interface alluxio.worker.block.BlockStore
Remove Storage directories that are no longer accessible.
removeInnerValue(K1, K2) - Method in class alluxio.collections.TwoKeyConcurrentMap
 
removeMetrics(String) - Static method in class alluxio.metrics.MetricsSystem
Removes the metric with the given name.
removeMount(long) - Method in interface alluxio.underfs.UfsManager
Removes the association from a mount id to a UFS instance.
removeSession(long) - Method in class alluxio.Sessions
Removes the given session from the session pool.
removeStorageDir(StorageDir) - Method in interface alluxio.worker.block.meta.StorageTier
Removes a directory.
removeTempBlockMeta(TempBlockMeta) - Method in interface alluxio.worker.block.meta.StorageDir
Removes a temp block from this storage dir.
removeTimer(ScheduledTimer) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Removes a timer from the scheduler.
RENAME_CANNOT_BE_TO_ROOT - alluxio.exception.ExceptionMessage
 
RENAME_DIRECTORY - alluxio.metrics.MetricInfo.UfsOps
 
RENAME_FILE - alluxio.metrics.MetricInfo.UfsOps
 
RenameBuffer() - Constructor for class alluxio.underfs.ObjectUnderFileSystem.RenameBuffer
Construct a new ObjectUnderFileSystem.RenameBuffer instance.
renameDirectory(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
renameDirectory(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
renameDirectory(String, String) - Method in interface alluxio.underfs.UnderFileSystem
Renames a directory from src to dst in under file system.
renameDirectory(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
renameFile(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
renameFile(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
renameFile(String, String) - Method in interface alluxio.underfs.UnderFileSystem
Renames a file from src to dst in under file system.
renameFile(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
renameRenamableDirectory(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
renameRenamableDirectory(String, String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
renameRenamableDirectory(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
renameRenamableDirectory(String, String) - Method in interface alluxio.underfs.UnderFileSystem
Renames a directory from src to dst in under file system.
renameRenamableDirectory(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
renameRenamableFile(String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
renameRenamableFile(String, String) - Method in class alluxio.underfs.ConsistentUnderFileSystem
 
renameRenamableFile(String, String) - Method in class alluxio.underfs.ObjectUnderFileSystem
 
renameRenamableFile(String, String) - Method in interface alluxio.underfs.UnderFileSystem
Renames a file from src to dst in under file system.
renameRenamableFile(String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
replace(K, V) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
replace(K, V, V) - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
REPLICATION_MAX_INFINITY - Static variable in class alluxio.Constants
 
report() - Method in class alluxio.metrics.sink.ConsoleSink
 
report() - Method in class alluxio.metrics.sink.CsvSink
 
report() - Method in class alluxio.metrics.sink.GraphiteSink
 
report() - Method in class alluxio.metrics.sink.JmxSink
 
report() - Method in interface alluxio.metrics.sink.Sink
Reports the current values of all metrics.
report() - Method in class alluxio.metrics.sink.Slf4jSink
 
reportClientMetrics() - Static method in class alluxio.metrics.MetricsSystem
 
reportTracedLeak(String, String) - Method in class alluxio.resource.AlluxioResourceLeakDetector
A traced leak report which includes records of the recent accesses of the particular object and the stacktrace of where the particular object was created.
reportUntracedLeak(String) - Method in class alluxio.resource.AlluxioResourceLeakDetector
An untraced leak report where there is no information about recent object accesses nor where the stacktrace of where the object was created.
reportWorkerMetrics() - Static method in class alluxio.metrics.MetricsSystem
 
requestSpace(long, long, long) - Method in interface alluxio.worker.block.BlockStore
Requests to increase the size of a temp block.
requestSpace(long, long, long) - Method in interface alluxio.worker.block.BlockWorker
Request an amount of space for a block in its storage directory.
reset() - Method in class alluxio.extensions.ExtensionFactoryRegistry
Resets the registry to its default state
reset() - Method in class alluxio.metrics.InstrumentedExecutorService
Resets the metrics monitored about the executor service.
reset() - Method in class alluxio.retry.CountingRetry
Reset the count of retries.
reset() - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Resets the registry to its default state
resetAllMetrics() - Static method in class alluxio.metrics.MetricsSystem
Resets all the metrics in the MetricsSystem.
resetCountersAndGauges() - Static method in class alluxio.metrics.MetricsSystem
Resets all counters to 0 and unregisters gauges for testing.
resetPrimaryMasterAddressCache() - Method in class alluxio.master.selectionpolicy.AbstractMasterSelectionPolicy
 
resetPrimaryMasterAddressCache() - Method in interface alluxio.master.selectionpolicy.MasterSelectionPolicy
Resets the cached primary master address.
resizeTempBlockMeta(TempBlockMeta, long) - Method in interface alluxio.worker.block.meta.StorageDir
Changes the size of a temp block.
resolveHostName(String) - Static method in class alluxio.util.network.NetworkAddressUtils
Resolves a given hostname by a canonical hostname.
resolveIpAddress(String) - Static method in class alluxio.util.network.NetworkAddressUtils
Resolves a given hostname IP address.
resolveUri(AlluxioURI, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
resolveUri(AlluxioURI, String) - Method in class alluxio.underfs.BaseUnderFileSystem
 
resolveUri(AlluxioURI, String) - Method in interface alluxio.underfs.UnderFileSystem
Returns an AlluxioURI representation for the UnderFileSystem given a base UFS URI, and the Alluxio path from the base.
resolveUri(AlluxioURI, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
ResourceExhaustedException - Exception in alluxio.exception.status
Exception indicating that some resource has been exhausted, perhaps a per-user quota, or perhaps the entire file system is out of space.
ResourceExhaustedException(String) - Constructor for exception alluxio.exception.status.ResourceExhaustedException
 
ResourceExhaustedException(String, Throwable) - Constructor for exception alluxio.exception.status.ResourceExhaustedException
 
ResourceExhaustedException(Throwable) - Constructor for exception alluxio.exception.status.ResourceExhaustedException
 
ResourceExhaustedRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that some resource has been exhausted, perhaps a per-user quota, or perhaps the task queue.
ResourceExhaustedRuntimeException(String, boolean) - Constructor for exception alluxio.exception.runtime.ResourceExhaustedRuntimeException
Constructor.
ResourceExhaustedRuntimeException(String, Throwable, boolean) - Constructor for exception alluxio.exception.runtime.ResourceExhaustedRuntimeException
Constructor.
ResourceInternal(R) - Constructor for class alluxio.resource.DynamicResourcePool.ResourceInternal
ResourcePool<T> - Class in alluxio.resource
Class representing a pool of resources to be temporarily used and returned.
ResourcePool(int) - Constructor for class alluxio.resource.ResourcePool
Creates a ResourcePool instance with the specified capacity.
ResourcePool(int, ConcurrentLinkedQueue<T>) - Constructor for class alluxio.resource.ResourcePool
Internal constructor that can provide an object to be used for the internal queue.
REST_API_PREFIX - Static variable in class alluxio.Constants
 
retainAll(Collection<?>) - Method in class alluxio.collections.ConcurrentHashSet
 
retainAll(Collection<?>) - Method in class alluxio.collections.DelegatingSet
 
retainAll(Collection<?>) - Method in class alluxio.collections.UnmodifiableArrayList
 
retry(String, RetryUtils.RunnableThrowsIOException, RetryPolicy) - Static method in class alluxio.retry.RetryUtils
Retries the given method until it doesn't throw an IO exception or the retry policy expires.
retryCallable(String, Callable<V>, RetryPolicy) - Static method in class alluxio.retry.RetryUtils
Notice we assume the exception with the method is retryable, so we are not wasting time here.
retryOnException(ObjectUnderFileSystem.ObjectStoreOperation<T>, Supplier<String>) - Method in class alluxio.underfs.ObjectUnderFileSystem
Retries the given object store operation when it throws exceptions to resolve eventual consistency issue.
RetryPolicy - Interface in alluxio.retry
Policy for determining whether retries should be performed, and potentially waiting for some time before the next retry attempt.
retryRPC(AbstractClient.RpcCallable<V>, Logger, String, String, Object...) - Method in class alluxio.AbstractClient
Tries to execute an RPC defined as a AbstractClient.RpcCallable.
retryRPC(RetryPolicy, AbstractClient.RpcCallable<V>, Logger, String, String, Object...) - Method in class alluxio.AbstractClient
 
RetryUtils - Class in alluxio.retry
Utilities for performing retries.
RetryUtils.RunnableThrowsIOException - Interface in alluxio.retry
Interface for methods which return nothing and may throw IOException.
REVISION - Static variable in class alluxio.ProjectConstants
 
ROCKS - alluxio.client.file.cache.store.PageStoreType
A store that utilizes RocksDB to store and retrieve pages.
ROCKS - alluxio.master.metastore.MetastoreType
 
ROCKS_BLOCK_CONF_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
ROCKS_BLOCK_CONF_FILE - Static variable in class alluxio.conf.PropertyKey
 
ROCKS_INODE_CONF_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
ROCKS_INODE_CONF_FILE - Static variable in class alluxio.conf.PropertyKey
 
RocksUtils - Class in alluxio.master.metastore.rocks
Convenience methods for working with RocksDB.
RocksUtils.RocksIteratorParser<T> - Interface in alluxio.master.metastore.rocks
Used to parse current RocksIterator element.
ROOT_CANNOT_BE_RENAMED - alluxio.exception.ExceptionMessage
 
ROOT_MOUNT_ID - Static variable in class alluxio.util.IdUtils
 
RPC - alluxio.grpc.GrpcNetworkGroup
Networking group for RPC traffic.
RPC_ASYNC_CACHE_REQUEST - alluxio.network.protocol.RPCMessage.Type
 
RPC_EXECUTOR_CORE_POOL_SIZE - alluxio.conf.PropertyKey.Template
 
RPC_EXECUTOR_FJP_ASYNC - alluxio.conf.PropertyKey.Template
 
RPC_EXECUTOR_FJP_MIN_RUNNABLE - alluxio.conf.PropertyKey.Template
 
RPC_EXECUTOR_FJP_PARALLELISM - alluxio.conf.PropertyKey.Template
 
RPC_EXECUTOR_KEEPALIVE - alluxio.conf.PropertyKey.Template
 
RPC_EXECUTOR_MAX_POOL_SIZE - alluxio.conf.PropertyKey.Template
 
RPC_EXECUTOR_TPE_ALLOW_CORE_THREADS_TIMEOUT - alluxio.conf.PropertyKey.Template
 
RPC_EXECUTOR_TPE_QUEUE_TYPE - alluxio.conf.PropertyKey.Template
 
RPC_EXECUTOR_TYPE - alluxio.conf.PropertyKey.Template
 
RPC_HEARTBEAT - alluxio.network.protocol.RPCMessage.Type
 
RPC_LOCAL_BLOCK_CLOSE_REQUEST - alluxio.network.protocol.RPCMessage.Type
 
RPC_LOCAL_BLOCK_COMPLETE_REQUEST - alluxio.network.protocol.RPCMessage.Type
 
RPC_LOCAL_BLOCK_CREATE_REQUEST - alluxio.network.protocol.RPCMessage.Type
 
RPC_LOCAL_BLOCK_CREATE_RESPONSE - alluxio.network.protocol.RPCMessage.Type
 
RPC_LOCAL_BLOCK_OPEN_REQUEST - alluxio.network.protocol.RPCMessage.Type
 
RPC_LOCAL_BLOCK_OPEN_RESPONSE - alluxio.network.protocol.RPCMessage.Type
 
RPC_READ_REQUEST - alluxio.network.protocol.RPCMessage.Type
 
RPC_READ_RESPONSE - alluxio.network.protocol.RPCMessage.Type
 
RPC_RESPONSE - alluxio.network.protocol.RPCMessage.Type
 
RPC_UNKNOWN - alluxio.network.protocol.RPCMessage.Type
 
RPC_WRITE_REQUEST - alluxio.network.protocol.RPCMessage.Type
 
RpcExecutorType - Enum in alluxio.executor
RPC ExecutorService types.
RPCHandler(Promise<ProtoMessage>) - Constructor for class alluxio.network.netty.NettyRPC.RPCHandler
Creates an instance of NettyRPC.RPCHandler.
RPCMessage - Class in alluxio.network.protocol
This is the main base class for all RPC messages to the DataServer.
RPCMessage() - Constructor for class alluxio.network.protocol.RPCMessage
 
RPCMessage.Type - Enum in alluxio.network.protocol
The possible types of RPC messages.
RPCMessageDecoder - Class in alluxio.network.protocol
Simple Netty decoder which converts the input ByteBuf into an RPCMessage.
RPCMessageDecoder() - Constructor for class alluxio.network.protocol.RPCMessageDecoder
Constructs a new RPCMessageDecoder.
RPCMessageEncoder - Class in alluxio.network.protocol
Simple Netty encoder for RPCMessages.
RPCMessageEncoder() - Constructor for class alluxio.network.protocol.RPCMessageEncoder
Constructs a new RPCMessageEncoder.
RPCProtoMessage - Class in alluxio.network.protocol
This is the main base class for all protocol buffer based RPC messages to the DataServer.
RPCProtoMessage(byte[], ProtoMessage, DataBuffer) - Constructor for class alluxio.network.protocol.RPCProtoMessage
Creates an instance of RPCProtoMessage from a serialized proto message.
RPCProtoMessage(ProtoMessage) - Constructor for class alluxio.network.protocol.RPCProtoMessage
Creates an instance of RPCProtoMessage without data part.
RPCProtoMessage(ProtoMessage, DataBuffer) - Constructor for class alluxio.network.protocol.RPCProtoMessage
Creates an instance of RPCProtoMessage.
run() - Method in class alluxio.concurrent.jsr.ForkJoinWorkerThread
This method is required to be public, but should never be called explicitly.
run() - Method in class alluxio.heartbeat.HeartbeatThread
 
run() - Method in class alluxio.network.RejectingServer
 
run() - Method in interface alluxio.retry.RetryUtils.RunnableThrowsIOException
Runs the runnable.
run() - Method in class alluxio.shell.ShellCommand
Runs a command and returns its stdout on success.
run(String...) - Method in class alluxio.cli.AbstractShell
Handles the specified shell command request, displaying usage if the command format is invalid.
run(CommandLine) - Method in interface alluxio.cli.Command
Runs the command.
runAfterBoth(CompletionStage<?>, Runnable) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
runAfterBoth(CompletionStage<?>, Runnable) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, executes the given action.
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, executes the given action using this stage's default asynchronous execution facility.
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
runAfterBothAsync(CompletionStage<?>, Runnable, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, executes the given action using the supplied executor.
runAfterEither(CompletionStage<?>, Runnable) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
runAfterEither(CompletionStage<?>, Runnable) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when either this or the other given stage complete normally, executes the given action.
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when either this or the other given stage complete normally, executes the given action using this stage's default asynchronous execution facility.
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
runAfterEitherAsync(CompletionStage<?>, Runnable, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when either this or the other given stage complete normally, executes the given action using the supplied executor.
runAllTests() - Method in interface alluxio.cli.ValidationTool
Runs validation tests.
runAsync(Runnable) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is asynchronously completed by a task running in the ForkJoinPool.commonPool() after it runs the given action.
runAsync(Runnable, Executor) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is asynchronously completed by a task running in the given executor after it runs the given action.
runExample(Callable<Boolean>) - Static method in class alluxio.cli.RunTestUtils
Runs an example.
runNextPendingCommand() - Method in class alluxio.util.executor.ControllableScheduler
Runs the next command scheduled to be executed immediately.
RunTestUtils - Class in alluxio.cli
Utilities to run the examples.
RUNTIME - alluxio.conf.Source.Type
The property value is set by user during runtime (e.g., Configuration.set or through HadoopConf).
RUNTIME - Static variable in class alluxio.conf.Source
 
RuntimeConstants - Class in alluxio
System constants that are determined during runtime.
runWithOutput() - Method in class alluxio.shell.ShellCommand
Runs a command and returns its output and exit code in Object.
RWLockResource - Class in alluxio.resource
The RWLockResource is an extension of the LockResource which allows for downgrading of locks.
RWLockResource(ReentrantReadWriteLock, LockMode, boolean, boolean) - Constructor for class alluxio.resource.RWLockResource
Creates a new instance of RW lock that will lock with the given mode.

S

S_CLIENT_ID_KEY - Static variable in class alluxio.security.authentication.ChannelIdInjector
Metadata key for the channel Id.
S3_DELETE_IN_ALLUXIO_AND_UFS - Static variable in class alluxio.Constants
 
S3_DELETE_IN_ALLUXIO_ONLY - Static variable in class alluxio.Constants
 
S3_REST_AUTHENTICATION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
S3_REST_AUTHENTICATION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
S3_REST_AUTHENTICATOR_CLASSNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
S3_REST_AUTHENTICATOR_CLASSNAME - Static variable in class alluxio.conf.PropertyKey
 
S3_UPLOADS_ID_XATTR_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
S3A_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
S3A_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey
 
S3A_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
S3A_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey
 
safeManagedBlock(ForkJoinPool.ManagedBlocker) - Static method in class alluxio.concurrent.ForkJoinPoolHelper
Does managed blocking on ForkJoinPool.
SamplingLogger - Class in alluxio.util.logging
A logger which limits log message frequency to prevent spamming the logs.
SamplingLogger(Logger, long) - Constructor for class alluxio.util.logging.SamplingLogger
 
SaslClientHandler - Interface in alluxio.security.authentication
Interface for authentication scheme specific SaslClient management.
SaslClientHandlerPlain - Class in alluxio.security.authentication.plain
SaslClientHandler implementation for Plain/Custom schemes.
SaslClientHandlerPlain(String, String, String) - Constructor for class alluxio.security.authentication.plain.SaslClientHandlerPlain
Creates SaslClientHandler instance for Plain/Custom.
SaslClientHandlerPlain(Subject, AlluxioConfiguration) - Constructor for class alluxio.security.authentication.plain.SaslClientHandlerPlain
Creates SaslClientHandler instance for Plain/Custom.
SaslServerHandler - Interface in alluxio.security.authentication
Interface for authentication scheme specific SaslServer management.
SaslServerHandlerPlain - Class in alluxio.security.authentication.plain
SaslServerHandler implementation for Plain/Custom schemes.
SaslServerHandlerPlain(String, AlluxioConfiguration, ImpersonationAuthenticator) - Constructor for class alluxio.security.authentication.plain.SaslServerHandlerPlain
Creates SaslServerHandler for Plain/Custom.
scanRegistered(String, S) - Method in class alluxio.extensions.ExtensionFactoryRegistry
Finds factories from registered collection.
schedule() - Method in class alluxio.heartbeat.ScheduledTimer
Schedules execution of the heartbeat.
schedule(Runnable, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
schedule(String) - Static method in class alluxio.heartbeat.HeartbeatScheduler
Schedules execution of a heartbeat for the given thread.
schedule(Callable<V>, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
scheduleAtFixedRate(Runnable, long, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
SCHEDULED_TIMER_CLASS - Static variable in class alluxio.heartbeat.HeartbeatContext
 
ScheduledTimer - Class in alluxio.heartbeat
This class can be used for controlling heartbeat execution of threads.
ScheduledTimer(String, long) - Constructor for class alluxio.heartbeat.ScheduledTimer
Creates a new instance of ScheduledTimer.
schedulerIsIdle() - Method in class alluxio.util.executor.ControllableScheduler
Reports whether scheduler has no commands/tasks pending immediate execution.
scheduleWithFixedDelay(Runnable, long, long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
SCHEMA - alluxio.client.quota.CacheScope.Level
 
SCHEME - Static variable in class alluxio.Constants
 
Scoped - Interface in alluxio.util.interfaces
Extension of Closeable which throws no checked exceptions.
ScpCommand - Class in alluxio.shell
Object representation of a remote scp command.
ScpCommand(String, String, String) - Constructor for class alluxio.shell.ScpCommand
Creates a remote scp command to copy a file to local.
ScpCommand(String, String, String, boolean) - Constructor for class alluxio.shell.ScpCommand
Creates a remote scp command to copy a file/dir to local.
scpCommandWithOutput(String, String, String, boolean) - Static method in class alluxio.util.ShellUtils
Static method to execute an scp command to copy a remote file/dir to local.
search(String) - Method in class alluxio.conf.path.TrieNode
Traverses the trie along the path components until the traversal cannot proceed any more.
searchExact(String) - Method in class alluxio.conf.path.TrieNode
Find terminal component of the full path if one exists.
SECOND - Static variable in class alluxio.Constants
 
SECOND_MS - Static variable in class alluxio.Constants
 
SECOND_NANO - Static variable in class alluxio.Constants
 
SECOND_TIER - Static variable in class alluxio.Constants
 
SECONDARY_MASTER_METASTORE_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
SECONDARY_MASTER_METASTORE_DIR - Static variable in class alluxio.conf.PropertyKey
 
SECRET - alluxio.grpc.GrpcNetworkGroup
Networking group for secret exchange.
SECURITY - alluxio.master.file.meta.xattr.ExtendedAttribute.NamespacePrefix
 
SECURITY_AUTHENTICATION_CUSTOM_PROVIDER_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHENTICATION_CUSTOM_PROVIDER_CLASS - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_AUTHENTICATION_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHENTICATION_TYPE - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_AUTHORIZATION_PERMISSION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHORIZATION_PERMISSION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_AUTHORIZATION_PERMISSION_SUPERGROUP - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHORIZATION_PERMISSION_SUPERGROUP - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_AUTHORIZATION_PERMISSION_UMASK - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_AUTHORIZATION_PERMISSION_UMASK - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_GROUP_MAPPING_CACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_GROUP_MAPPING_CACHE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_GROUP_MAPPING_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_GROUP_MAPPING_CLASS - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_LOGIN_IMPERSONATION_USERNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_LOGIN_IMPERSONATION_USERNAME - Static variable in class alluxio.conf.PropertyKey
 
SECURITY_LOGIN_USERNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
SECURITY_LOGIN_USERNAME - Static variable in class alluxio.conf.PropertyKey
 
SecurityUtils - Class in alluxio.util
Utility methods for security.
seek(long) - Method in class alluxio.file.SeekableBufferedInputStream
 
seek(long) - Method in interface alluxio.Seekable
Moves the starting read position of the stream to the specified position which is relative to the start of the stream.
Seekable - Interface in alluxio
This interface should be implemented by all Alluxio streams which support moving the read position to a specific byte offset.
SeekableBufferedInputStream - Class in alluxio.file
A class optimizes seekable input streams by providing buffering.
SeekableBufferedInputStream(InputStream, int) - Constructor for class alluxio.file.SeekableBufferedInputStream
Constructor.
SeekableUnderFileInputStream - Class in alluxio.underfs
A seekable under file input stream wrapper that encapsulates the under file input stream.
SeekableUnderFileInputStream(InputStream) - Constructor for class alluxio.underfs.SeekableUnderFileInputStream
 
SelectionPolicyAnyMaster - Class in alluxio.master.selectionpolicy
The master selection policy that connects to a random master.
SelectionPolicyAnyMaster() - Constructor for class alluxio.master.selectionpolicy.SelectionPolicyAnyMaster
 
SelectionPolicyAnyStandbyMaster - Class in alluxio.master.selectionpolicy
The master connection mode that connects to a random standby master.
SelectionPolicyAnyStandbyMaster() - Constructor for class alluxio.master.selectionpolicy.SelectionPolicyAnyStandbyMaster
Creates a new standby connection mode that picks the standby master randomly.
SelectionPolicyAnyStandbyMaster(long) - Constructor for class alluxio.master.selectionpolicy.SelectionPolicyAnyStandbyMaster
Creates a new standby connection mode that picks the standby master deterministically with a random seed.
SelectionPolicyPrimaryMaster - Class in alluxio.master.selectionpolicy
The master selection policy that connects to the primary master.
SelectionPolicyPrimaryMaster() - Constructor for class alluxio.master.selectionpolicy.SelectionPolicyPrimaryMaster
 
SelectionPolicySpecifiedMaster - Class in alluxio.master.selectionpolicy
The master selection policy that connects to the specified master.
SelectionPolicySpecifiedMaster(InetSocketAddress) - Constructor for class alluxio.master.selectionpolicy.SelectionPolicySpecifiedMaster
Creates a new selection policy that specifies a master address to client.
SensitiveConfigMask - Interface in alluxio.conf
Mask some sensitive information.
SEPARATOR - Static variable in class alluxio.AlluxioURI
 
SEPARATOR - Static variable in class alluxio.client.quota.CacheScope
 
serialize() - Method in class alluxio.underfs.Fingerprint
 
serialize(ReadResponse) - Method in class alluxio.grpc.ReadResponseMarshaller
 
serialize(WriteRequest) - Method in class alluxio.grpc.WriteRequestMarshaller
 
serialize(AccessControlList, JsonGenerator, SerializerProvider) - Method in class alluxio.security.authorization.AccessControlList.AccessControlListSerializer
Serialize an AccessControlList object.
serialize(T) - Method in class alluxio.grpc.DataMessageMarshaller
Serialize the message to buffers.
Server<T> - Interface in alluxio
Interface representing an Alluxio server.
SERVER - alluxio.metrics.MetricsSystem.InstanceType
 
ServiceNotFoundException - Exception in alluxio.exception
Exception used when the service is not provided by the server.
ServiceNotFoundException(String, Throwable) - Constructor for exception alluxio.exception.ServiceNotFoundException
Constructs a new exception with the specified detail message and cause.
ServiceVersionClientServiceHandler - Class in alluxio.grpc
This class is a gRPC handler that serves Alluxio service versions.
ServiceVersionClientServiceHandler(Set<ServiceType>) - Constructor for class alluxio.grpc.ServiceVersionClientServiceHandler
Creates service version handler that allows given services.
SESSION - alluxio.master.ZookeeperConnectionErrorPolicy
 
SESSION_NOT_CLOSED - alluxio.exception.ExceptionMessage
 
SessionCleanable - Interface in alluxio.worker
Interface for classes which track sessions and provide a method to clean any expired sessions.
SessionInfo - Class in alluxio
Represents one session in the worker daemon.
SessionInfo(long, int) - Constructor for class alluxio.SessionInfo
Creates a new instance of SessionInfo.
Sessions - Class in alluxio
Sessions represents and manages all sessions contacting a worker.
Sessions() - Constructor for class alluxio.Sessions
Creates a new instance of Sessions.
set(int) - Method in interface alluxio.collections.BitSet
Sets the bit at the specified index to true.
set(int) - Method in class alluxio.collections.BuiltinBitSet
 
set(int, T) - Method in class alluxio.collections.UnmodifiableArrayList
 
set(PropertyKey, Object) - Method in class alluxio.conf.AlluxioProperties
Puts the key value pair specified by users.
set(PropertyKey, Object) - Static method in class alluxio.conf.Configuration
Sets the value for the appropriate key in the Properties.
set(PropertyKey, Object) - Method in class alluxio.conf.InstancedConfiguration
Sets the value for the appropriate key in the Properties.
set(PropertyKey, Object, Source) - Static method in class alluxio.conf.Configuration
Sets the value for the appropriate key in the Properties by source.
set(PropertyKey, Object, Source) - Method in class alluxio.conf.InstancedConfiguration
Sets the value for the appropriate key in the Properties by source.
set(PropertyKey, String) - Method in class alluxio.conf.InstancedConfiguration
Deprecated.
API to aid property key type transition
set(User) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Sets User to the ThreadLocal variable.
set(String) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Creates a User and sets it to the ThreadLocal variable.
SET_MODE - alluxio.metrics.MetricInfo.UfsOps
 
SET_OWNER - alluxio.metrics.MetricInfo.UfsOps
 
SET_PERMISSION_COMMAND - Static variable in class alluxio.util.ShellUtils
a Unix command to set permission.
setAccessControlException(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets access control exception.
setAcl(AccessControlList) - Method in class alluxio.underfs.options.CreateOptions
Sets an initial acl for the newly created file.
setAcl(AccessControlList) - Method in class alluxio.wire.FileInfo
 
setAclEntries(String, List<AclEntry>) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
setAclEntries(String, List<AclEntry>) - Method in class alluxio.underfs.BaseUnderFileSystem
 
setAclEntries(String, List<AclEntry>) - Method in interface alluxio.underfs.UnderFileSystem
Sets the access control list of a file or directory in under file system.
setAclEntries(String, List<AclEntry>) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
setActions(AclActions) - Method in class alluxio.security.authorization.AclEntry.Builder
Sets a copy of actions for this entry.
setAddress(Address) - Method in class alluxio.wire.MasterInfo
 
setAddress(WorkerNetAddress) - Method in class alluxio.wire.WorkerInfo
 
setAdvice(String) - Method in class alluxio.cli.ValidationTaskResult
Sets task advice.
setAlias(String...) - Method in class alluxio.conf.PropertyKey.Builder
 
setAlluxioPath(String) - Method in class alluxio.worker.block.CreateBlockOptions
 
setAuthenticatedUserInfo(AuthenticatedUserInfo) - Method in class alluxio.security.authentication.plain.SaslServerHandlerPlain
 
setAuthenticatedUserInfo(AuthenticatedUserInfo) - Method in interface alluxio.security.authentication.SaslServerHandler
To be called by callbacks to store authenticated user information.
setAuthMethod(String) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Sets the connection authentication method to the ThreadLocal variable.
setBackupId(UUID) - Method in class alluxio.wire.BackupStatus
Sets the unique backup id.
setBackupUri(AlluxioURI) - Method in class alluxio.wire.BackupStatus
Sets the backup uri.
setBlockCount(long) - Method in class alluxio.wire.WorkerInfo
 
setBlockCount(String) - Method in class alluxio.wire.WorkerWebUIOverview
Sets worker block count.
setBlockId(long) - Method in class alluxio.wire.BlockInfo
 
setBlockIds(List<Long>) - Method in class alluxio.wire.FileInfo
 
setBlockIds(List<Long>) - Method in class alluxio.wire.PersistFile
Set the block ids.
setBlockInfo(BlockInfo) - Method in class alluxio.wire.FileBlockInfo
 
setBlockSize(long) - Method in interface alluxio.worker.block.meta.TempBlockMeta
 
setBlockSizeBytes(long) - Method in class alluxio.wire.FileInfo
 
setBlockSizeBytes(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets block size bytes.
setBlockSizeBytes(String) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets block size bytes.
setCacheable(boolean) - Method in class alluxio.wire.FileInfo
 
setCacheHitLocal(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets cache hit local.
setCacheHitRemote(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets cache hit remote.
setCacheIdentifier(String) - Method in class alluxio.client.file.CacheContext
 
setCacheMiss(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets cache miss.
setCacheQuota(CacheQuota) - Method in class alluxio.client.file.CacheContext
 
setCacheScope(CacheScope) - Method in class alluxio.client.file.CacheContext
 
setCapacity(Capacity) - Method in class alluxio.wire.AlluxioMasterInfo
 
setCapacity(Capacity) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets capacity.
setCapacityBytes(long) - Method in class alluxio.wire.BlockMasterInfo
 
setCapacityBytes(long) - Method in class alluxio.wire.WorkerInfo
 
setCapacityBytes(String) - Method in class alluxio.wire.WorkerWebUIOverview
Sets capacity bytes.
setCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.BlockMasterInfo
 
setCapacityBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.WorkerInfo
 
setChannel(Channel) - Method in class alluxio.network.netty.NettyRPCContext
 
setClassName(String) - Method in interface alluxio.util.JsonSerializable
 
setClientObserver(StreamObserver<SaslMessage>) - Method in class alluxio.security.authentication.AuthenticatedChannelServerDriver
Sets the client's Sasl stream.
setClusterConfHash(String) - Method in class alluxio.wire.Configuration.Builder
Sets hash of path configurations.
setClusterId(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets cluster id.
setCommandOptions(FileSystemCommandOptions) - Method in class alluxio.wire.FileSystemCommand
Set the command options.
setCommandType(CommandType) - Method in class alluxio.wire.FileSystemCommand
Set the command type.
setCompleted(boolean) - Method in class alluxio.wire.FileInfo
 
setConfigCheckErrorNum(int) - Method in class alluxio.wire.MasterWebUIOverview
Sets config check error num.
setConfigCheckErrors(Map<Scope, List<InconsistentProperty>>) - Method in class alluxio.wire.MasterWebUIOverview
Sets config check errors.
setConfigCheckStatus(ConfigStatus) - Method in class alluxio.wire.MasterWebUIOverview
Sets config check status.
setConfigCheckWarnNum(int) - Method in class alluxio.wire.MasterWebUIOverview
Sets config check warn num.
setConfigCheckWarns(Map<Scope, List<InconsistentProperty>>) - Method in class alluxio.wire.MasterWebUIOverview
Sets config check warns.
setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioProxyInfo
 
setConfiguration(Map<String, Object>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setConfiguration(TreeSet<Triple<String, String, String>>) - Method in class alluxio.wire.MasterWebUIConfiguration
Sets configuration.
setConfiguration(TreeSet<Triple<String, String, String>>) - Method in class alluxio.wire.WorkerWebUIConfiguration
Sets configuration.
setConnectionUser(String) - Static method in class alluxio.security.authentication.AuthenticatedClientUser
Creates a connection User and sets it to the ThreadLocal variable.
setConsistencyCheckLevel(PropertyKey.ConsistencyCheckLevel) - Method in class alluxio.conf.PropertyKey.Builder
 
setContainerHost(String) - Method in class alluxio.wire.WorkerNetAddress
 
setCreateParent(boolean) - Method in class alluxio.underfs.options.CreateOptions
Sets option to force creation of parent directories.
setCreateParent(boolean) - Method in class alluxio.underfs.options.MkdirsOptions
Sets option to create parent directories.
setCreationTimeMs(long) - Method in class alluxio.wire.FileInfo
 
setCurrentDirectory(UIFileInfo) - Method in class alluxio.wire.MasterWebUIBrowse
Sets current directory.
setCurrentPath(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets current path.
setCurrentPath(String) - Method in class alluxio.wire.MasterWebUILogs
Sets current path.
setCurrentPath(String) - Method in class alluxio.wire.WorkerWebUILogs
Sets current path.
setDataPort(int) - Method in class alluxio.wire.WorkerNetAddress
 
setDebug(boolean) - Method in class alluxio.wire.MasterWebUIBrowse
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.MasterWebUIInit
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.MasterWebUILogs
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.MasterWebUIMasters
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.MasterWebUIMountTable
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.MasterWebUIOverview
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.MasterWebUIWorkers
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.WorkerWebUIInit
Sets debug.
setDebug(boolean) - Method in class alluxio.wire.WorkerWebUILogs
Sets debug.
setDefault(boolean) - Method in class alluxio.security.authorization.AclEntry
Sets the entry to be default.
setDefaultAcl(DefaultAccessControlList) - Method in class alluxio.wire.FileInfo
 
setDefaultSupplier(DefaultSupplier) - Method in class alluxio.conf.PropertyKey.Builder
 
setDefaultSupplier(Supplier<Object>, String) - Method in class alluxio.conf.PropertyKey.Builder
 
setDefaultValue(Object) - Method in class alluxio.conf.PropertyKey.Builder
 
setDelay(long) - Method in class alluxio.util.executor.ControllableQueue.DelayNode
Sets the delay.
setDesc(String) - Method in class alluxio.cli.ValidationTaskResult
Sets task name.
setDescription(String) - Method in class alluxio.conf.PropertyKey.Builder
 
setDescription(String) - Method in class alluxio.metrics.MetricKey.Builder
 
setDeviceSpec(String) - Method in class alluxio.util.UnixMountInfo.Builder
 
setDiskCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets disk capacity.
setDiskFreeCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets disk free capacity.
setDiskUsedCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets disk used capacity.
setDisplayType(PropertyKey.DisplayType) - Method in class alluxio.conf.PropertyKey.Builder
 
setDomainSocketPath(String) - Method in class alluxio.wire.WorkerNetAddress
 
setEmpty(boolean) - Method in class alluxio.security.authorization.DefaultAccessControlList
 
setEnsureAtomic(boolean) - Method in class alluxio.underfs.options.CreateOptions
Set atomicity guarantees.
setEntry(AclEntry) - Method in class alluxio.security.authorization.AccessControlList
Sets an entry into the access control list.
setEntry(AclEntry) - Method in class alluxio.security.authorization.DefaultAccessControlList
 
setEntry(AclEntry) - Method in class alluxio.security.authorization.ExtendedACLEntries
Sets an entry into the access control list.
setEntryCount(long) - Method in class alluxio.wire.BackupStatus
Sets entry count.
setError(AlluxioException) - Method in class alluxio.wire.BackupStatus
Fails the backup with given error.
setError(Throwable) - Method in class alluxio.thread.AutopsyThread
Sets the error before exiting.
setEvictionAllowed(boolean) - Method in class alluxio.worker.block.AllocateOptions
Sets value for whether eviction is allowed for allocation.
setFailedMasterInfos(MasterInfo[]) - Method in class alluxio.wire.MasterWebUIMasters
Sets failed master infos.
setFailedNodeInfos(NodeInfo[]) - Method in class alluxio.wire.MasterWebUIWorkers
Sets failed node infos.
setFatalError(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets fatal error.
setFatalError(String) - Method in class alluxio.wire.MasterWebUIData
Sets fatal error.
setFatalError(String) - Method in class alluxio.wire.MasterWebUILogs
Sets fatal error.
setFatalError(String) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets fatal error.
setFatalError(String) - Method in class alluxio.wire.WorkerWebUILogs
Sets fatal error.
setFIFO(boolean) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setFileBlockInfos(List<FileBlockInfo>) - Method in class alluxio.wire.FileInfo
 
setFileBlocks(List<UIFileBlockInfo>) - Method in class alluxio.wire.MasterWebUIBrowse
Sets file blocks.
setFileBlocksOnTier(List<ImmutablePair<String, List<UIFileBlockInfo>>>) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets file blocks on tier.
setFileData(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets file data.
setFileData(String) - Method in class alluxio.wire.MasterWebUILogs
Sets file data.
setFileData(String) - Method in class alluxio.wire.WorkerWebUILogs
Sets file data.
setFileDoesNotExistException(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets file does not exist exception.
setFileId(long) - Method in class alluxio.wire.FileInfo
 
setFileId(long) - Method in class alluxio.wire.PersistFile
Set the file id.
setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.MasterWebUIBrowse
Sets file infos.
setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.MasterWebUIData
Sets file infos.
setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.MasterWebUILogs
Sets file infos.
setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets file infos.
setFileInfos(List<UIFileInfo>) - Method in class alluxio.wire.WorkerWebUILogs
Sets file infos.
setFileLocations(List<String>) - Method in class alluxio.util.webui.UIFileInfo
Sets file locations.
setFilesToPersist(List<PersistFile>) - Method in class alluxio.wire.PersistCommandOptions
Set the list of files to persist.
setFirst(T1) - Method in class alluxio.collections.Pair
Set the first value.
setFolder(boolean) - Method in class alluxio.wire.FileInfo
 
setForceLocation(boolean) - Method in class alluxio.worker.block.AllocateOptions
Sets value for whether to enforce location of allocation.
setForkJoinTaskTag(short) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Atomically sets the tag value for this task and returns the old value.
setFreeBytes(long) - Method in class alluxio.wire.BlockMasterInfo
 
setFreeCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets free capacity.
setFsType(String) - Method in class alluxio.util.UnixMountInfo.Builder
 
setGcExecutor(ScheduledExecutorService) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setGcIntervalMs(long) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setGroup(String) - Method in class alluxio.underfs.options.CreateOptions
 
setGroup(String) - Method in class alluxio.underfs.options.MkdirsOptions
 
setGroup(String) - Method in class alluxio.wire.FileInfo
 
setGroupBits(Mode.Bits) - Method in class alluxio.security.authorization.Mode
Sets group bits.
setHighestTierAlias(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets highest tier alias.
setHiveCacheContext(HiveCacheContext) - Method in class alluxio.client.file.CacheContext
 
setHost(String) - Method in class alluxio.wire.Address
 
setHost(String) - Method in class alluxio.wire.WorkerNetAddress
 
setHostname(String) - Method in class alluxio.wire.BackupStatus
Sets the backup host.
setId(long) - Method in class alluxio.wire.MasterInfo
 
setId(long) - Method in class alluxio.wire.WorkerInfo
 
setIgnoredSiteProperty(boolean) - Method in class alluxio.conf.PropertyKey.Builder
 
setInAlluxioFileNum(int) - Method in class alluxio.wire.MasterWebUIData
Sets in alluxio file num.
setInAlluxioPercentage(int) - Method in class alluxio.wire.FileInfo
 
setInitialBytes(long) - Method in class alluxio.worker.block.CreateBlockOptions
 
setInitialDelayMs(long) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setInMemoryPercentage(int) - Method in class alluxio.wire.FileInfo
 
setInterval(int) - Method in class alluxio.util.WaitForOptions
 
setIntervalMs(long) - Method in interface alluxio.heartbeat.HeartbeatTimer
Sets the heartbeat interval.
setIntervalMs(long) - Method in class alluxio.heartbeat.SleepingTimer
 
setInvalidPathError(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets invalid path error.
setInvalidPathError(String) - Method in class alluxio.wire.MasterWebUILogs
Sets invalid path error.
setInvalidPathError(String) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets invalid path error.
setInvalidPathError(String) - Method in class alluxio.wire.WorkerWebUILogs
Sets invalid path error.
setInvalidPathException(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets invalid path exception.
setIsBuiltIn(boolean) - Method in class alluxio.conf.PropertyKey.Builder
 
setIsClusterAggregated(boolean) - Method in class alluxio.metrics.MetricKey.Builder
 
setIsDefault(boolean) - Method in class alluxio.security.authorization.AclEntry.Builder
Set this AclEntry to be for default ACL.
setIsDynamic(boolean) - Method in class alluxio.conf.PropertyKey.Builder
 
setIsHidden(boolean) - Method in class alluxio.conf.PropertyKey.Builder
 
setJournalCheckpointTimeWarning(String) - Method in class alluxio.wire.MasterWebUIOverview
 
setJournalDiskMetrics(List<JournalDiskInfo>) - Method in class alluxio.wire.MasterWebUIMetrics
 
setJournalDiskWarnings(List<String>) - Method in class alluxio.wire.MasterWebUIOverview
 
setJournalEntriesSinceCheckpoint(long) - Method in class alluxio.wire.MasterWebUIMetrics
 
setJournalLastCheckpointTime(String) - Method in class alluxio.wire.MasterWebUIMetrics
 
setLastAccessTimeMs(long) - Method in class alluxio.resource.DynamicResourcePool.ResourceInternal
 
setLastAccessTimeMs(long) - Method in class alluxio.wire.FileInfo
 
setLastContactSec(int) - Method in class alluxio.wire.WorkerInfo
 
setLastModificationTimeMs(long) - Method in class alluxio.wire.FileInfo
 
setLastUpdatedTimeMs(long) - Method in class alluxio.wire.MasterInfo
 
setLeaderId(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets the leader id.
setLeaderMasterInfo(MasterInfo) - Method in class alluxio.wire.MasterWebUIMasters
Sets leader master info.
setLength(long) - Method in class alluxio.underfs.options.OpenOptions
 
setLength(long) - Method in class alluxio.wire.BlockInfo
 
setLength(long) - Method in class alluxio.wire.FileInfo
 
setLevel(String) - Method in class alluxio.wire.LogInfo
 
setLiveWorkerNodes(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets live worker nodes.
setLiveWorkerNum(int) - Method in class alluxio.wire.BlockMasterInfo
 
setLocalDirStickyBit(String) - Static method in class alluxio.util.io.FileUtils
Sticky bit can be set primarily on directories in UNIX / Linux.
setLocation(BlockStoreLocation) - Method in class alluxio.worker.block.AllocateOptions
Sets the allocation location.
setLocations(List<BlockLocation>) - Method in class alluxio.wire.BlockInfo
 
setLogLevel(String, String) - Static method in class alluxio.util.LogUtils
Gets a logger's level with specify name, if the level argument is not null, it will set to specify level first.
setLogName(String) - Method in class alluxio.wire.LogInfo
 
setLostWorkerNum(int) - Method in class alluxio.wire.BlockMasterInfo
 
setLostWorkers(List<WorkerInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setMasterCapacityFreePercentage(int) - Method in class alluxio.wire.MasterWebUIMetrics
Sets master capacity free percentage.
setMasterCapacityUsedPercentage(int) - Method in class alluxio.wire.MasterWebUIMetrics
Sets master capacity used percentage.
setMasterHostname(String) - Method in class alluxio.wire.WorkerWebUIInit
Sets master ip.
setMasterInquireClient(MasterInquireClient) - Method in class alluxio.master.MasterClientContextBuilder
Set the MasterInquireClient that the config will use.
setMasterNodeAddress(String) - Method in class alluxio.wire.MasterWebUIBrowse
Sets master node address.
setMasterNodeAddress(String) - Method in class alluxio.wire.MasterWebUIData
Sets master node address.
setMasterNodeAddress(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets master node address.
setMasterPort(int) - Method in class alluxio.wire.WorkerWebUIInit
Sets master port.
setMasterRole(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets the master role name.
setMasterUnderfsCapacityFreePercentage(int) - Method in class alluxio.wire.MasterWebUIMetrics
Sets master underfs capacity free percentage.
setMasterUnderfsCapacityUsedPercentage(int) - Method in class alluxio.wire.MasterWebUIMetrics
Sets master underfs capacity used percentage.
setMaxCapacity(int) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setMedium(String) - Method in class alluxio.worker.block.CreateBlockOptions
 
setMediumType(String) - Method in class alluxio.wire.BlockLocation
 
setMediumTypes(Set<String>) - Method in class alluxio.wire.FileInfo
 
setMessage(String) - Method in class alluxio.wire.LogInfo
 
setMetrics(Map<String, Long>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setMetrics(Map<String, Long>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setMetricType(MetricType) - Method in class alluxio.metrics.MetricKey.Builder
 
setMinCapacity(int) - Method in class alluxio.resource.DynamicResourcePool.Options
 
setMode(int) - Method in class alluxio.wire.FileInfo
 
setMode(short) - Method in class alluxio.security.authorization.AccessControlList
Sets permitted actions for owning user, owning group, and other based on the mode.
setMode(Mode) - Method in class alluxio.underfs.options.CreateOptions
 
setMode(Mode) - Method in class alluxio.underfs.options.MkdirsOptions
 
setMode(String, short) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
setMode(String, short) - Method in interface alluxio.underfs.UnderFileSystem
Changes posix file mode.
setMode(String, short) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
setMountId(long) - Method in class alluxio.wire.FileInfo
 
setMountId(long) - Method in class alluxio.wire.MountPointInfo
 
setMountOptions(MountPOptions) - Method in class alluxio.wire.UfsInfo
 
setMountPoint(boolean) - Method in class alluxio.wire.FileInfo
 
setMountPoint(String) - Method in class alluxio.util.UnixMountInfo.Builder
 
setMountPointInfos(Map<String, MountPointInfo>) - Method in class alluxio.wire.MasterWebUIMountTable
Sets mount point infos.
setMountPoints(Map<String, MountPointInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setName(String) - Method in class alluxio.cli.ValidationTaskResult
Sets task name.
setName(String) - Method in class alluxio.conf.PropertyKey.Builder
 
setName(String) - Method in class alluxio.metrics.MetricKey.Builder
 
setName(String) - Method in class alluxio.underfs.UfsStatus
Set the name of file or directory.
setName(String) - Method in class alluxio.wire.FileInfo
 
setName(String) - Method in class alluxio.wire.InconsistentProperty
 
setNettyDataPort(int) - Method in class alluxio.wire.WorkerNetAddress
 
setNetworkGroup(GrpcNetworkGroup) - Method in class alluxio.grpc.GrpcChannelBuilder
Sets the pooling strategy.
setNewerVersionAvailable(boolean) - Method in class alluxio.wire.MasterWebUIInit
Sets newer version available.
setNormalMasterInfos(MasterInfo[]) - Method in class alluxio.wire.MasterWebUIMasters
Sets normal master infos.
setNormalNodeInfos(NodeInfo[]) - Method in class alluxio.wire.MasterWebUIWorkers
Sets normal node infos.
setNTotalFile(int) - Method in class alluxio.wire.MasterWebUIBrowse
Sets n total file.
setNTotalFile(int) - Method in class alluxio.wire.MasterWebUILogs
Sets n total file.
setNTotalFile(int) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets n total file.
setNTotalFile(int) - Method in class alluxio.wire.WorkerWebUILogs
Sets n total file.
setOffset(long) - Method in class alluxio.underfs.options.FileLocationOptions
Sets the offset for which locations are to be queried.
setOffset(long) - Method in class alluxio.underfs.options.OpenOptions
Sets the offset from the start of a file to be opened for reading.
setOffset(long) - Method in class alluxio.wire.FileBlockInfo
 
setOperationMetrics(Map<String, Metric>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets operation metrics.
setOperationMetrics(Map<String, Metric>) - Method in class alluxio.wire.WorkerWebUIMetrics
Sets operation metrics.
setOptions(UnixMountInfo.Options) - Method in class alluxio.util.UnixMountInfo.Builder
 
setOrderedTierAliases(List<String>) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets ordered tier aliases.
setOtherBits(Mode.Bits) - Method in class alluxio.security.authorization.Mode
Sets other bits.
setOutput(String) - Method in class alluxio.cli.ValidationTaskResult
Sets task output.
setOwner(String) - Method in class alluxio.underfs.options.CreateOptions
 
setOwner(String) - Method in class alluxio.underfs.options.MkdirsOptions
 
setOwner(String) - Method in class alluxio.wire.FileInfo
 
setOwner(String, String, String) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
setOwner(String, String, String) - Method in interface alluxio.underfs.UnderFileSystem
Sets the user and group of the given path.
setOwner(String, String, String) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
setOwnerBits(Mode.Bits) - Method in class alluxio.security.authorization.Mode
Sets owner bits.
setOwningGroup(String) - Method in class alluxio.security.authorization.AccessControlList
Sets owning group.
setOwningUser(String) - Method in class alluxio.security.authorization.AccessControlList
Sets owning user.
setPath(String) - Method in class alluxio.job.JobDescription.Builder
set path.
setPath(String) - Method in class alluxio.wire.FileInfo
 
setPath(String) - Method in class alluxio.wire.WorkerWebUIBlockInfo
Sets path.
setPathConfHash(String) - Method in class alluxio.wire.Configuration.Builder
Sets hash of path configurations.
setPathInfos(UIFileInfo[]) - Method in class alluxio.wire.MasterWebUIBrowse
Sets path infos.
setPendingCount(int) - Method in class alluxio.concurrent.jsr.CountedCompleter
Sets the pending count to the given value.
setPermissionError(String) - Method in class alluxio.wire.MasterWebUIData
Sets permission error.
setPersisted(boolean) - Method in class alluxio.wire.FileInfo
 
setPersistenceState(String) - Method in class alluxio.wire.FileInfo
 
setPersistOptions(PersistCommandOptions) - Method in class alluxio.wire.FileSystemCommandOptions
Set the persist options.
setPinned(boolean) - Method in class alluxio.wire.FileInfo
 
setPositionShort(boolean) - Method in class alluxio.underfs.options.OpenOptions
 
setProperties(Map<String, String>) - Method in class alluxio.wire.MountPointInfo
 
setProxyDownloadFileApiUrl(Map<String, String>) - Method in class alluxio.wire.MasterWebUIInit
Sets proxy download file api url.
setRawResult(T) - Method in class alluxio.concurrent.jsr.CountedCompleter
A method that result-bearing CountedCompleters may optionally use to help maintain result data.
setRawResult(V) - Method in class alluxio.concurrent.jsr.ForkJoinTask
Forces the given value to be returned as a result.
setReadOnly(boolean) - Method in class alluxio.wire.MountPointInfo
 
setRecoverFailedOpen(boolean) - Method in class alluxio.underfs.options.OpenOptions
 
setRecursive(boolean) - Method in class alluxio.underfs.options.DeleteOptions
Sets recursive delete.
setRecursive(boolean) - Method in class alluxio.underfs.options.ListOptions
Sets recursive list.
setRefreshInterval(int) - Method in class alluxio.wire.MasterWebUIInit
Sets refresh interval.
setRefreshInterval(int) - Method in class alluxio.wire.WorkerWebUIInit
Sets refresh interval.
setReplicaBlockCount(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets replica block count.
setReplicationMax(int) - Method in class alluxio.wire.FileInfo
 
setReplicationMin(int) - Method in class alluxio.wire.FileInfo
 
setResult(Map<ValidationUtils.State, List<ValidationTaskResult>>) - Method in class alluxio.cli.ValidationResults
Set validation results.
setRevision(String) - Method in class alluxio.wire.WorkerInfo
 
setRpcAddress(String) - Method in class alluxio.wire.AlluxioMasterInfo
 
setRpcAddress(String) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setRpcInvocationMetrics(Map<String, Counter>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets rpc invocation metrics.
setRpcPort(int) - Method in class alluxio.wire.Address
 
setRpcPort(int) - Method in class alluxio.wire.WorkerNetAddress
 
setScope(Scope) - Method in class alluxio.conf.PropertyKey.Builder
 
setSecond(T2) - Method in class alluxio.collections.Pair
Set the second value.
setSecurityAuthorizationPermissionEnabled(boolean) - Method in class alluxio.wire.MasterWebUIInit
Sets security authorization permission enabled.
setSecurityAuthorizationPermissionEnabled(boolean) - Method in class alluxio.wire.WorkerWebUIInit
Sets security authorization permission enabled.
setServerObserver(StreamObserver<SaslMessage>) - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
Sets the server's Sasl stream.
setShared(boolean) - Method in class alluxio.wire.MountPointInfo
 
setShowPermissions(boolean) - Method in class alluxio.wire.MasterWebUIBrowse
Sets show permissions.
setShowPermissions(boolean) - Method in class alluxio.wire.MasterWebUIData
Sets show permissions.
setSize(long) - Method in class alluxio.worker.block.AllocateOptions
Sets the allocation size.
setSize(Long) - Method in class alluxio.util.UnixMountInfo.Options.Builder
 
setSource(PropertyKey, Source) - Method in class alluxio.conf.AlluxioProperties
Sets the source for a given key.
setStartTime(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets start time.
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioMasterInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioProxyInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setStartTimeMs(long) - Method in class alluxio.wire.WorkerInfo
 
setState(ValidationUtils.State) - Method in class alluxio.cli.ValidationTaskResult
Sets task state.
setState(BackupState) - Method in class alluxio.wire.BackupStatus
Sets the backup state.
setState(String) - Method in class alluxio.wire.WorkerInfo
 
setStorageDirs(List<UIStorageDir>) - Method in class alluxio.wire.WorkerWebUIOverview
Sets storage dirs.
setStorageTierInfos(List<StorageTierInfo>) - Method in class alluxio.wire.MasterWebUIOverview
Sets storage tier infos.
setSubject(String) - Method in class alluxio.security.authorization.AclEntry.Builder
Sets subject of this entry.
setSubject(Subject) - Method in class alluxio.grpc.GrpcChannelBuilder
Sets Subject for authentication.
setTemporary(boolean) - Method in class alluxio.client.file.CacheContext
 
setTierAlias(String) - Method in class alluxio.wire.BlockLocation
 
setTierCapacity(Map<String, Capacity>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setTierCapacity(Map<String, Capacity>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setTieredIdentity(TieredIdentity) - Method in class alluxio.wire.WorkerNetAddress
 
setTierPaths(Map<String, List<String>>) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setTimeout(long) - Method in class alluxio.network.netty.NettyRPCContext
 
setTimeoutMs(int) - Method in class alluxio.util.WaitForOptions
 
setTimeSeriesMetrics(List<TimeSeries>) - Method in class alluxio.wire.MasterWebUIMetrics
 
setTotal(long) - Method in class alluxio.wire.Capacity
 
setTotalBytesReadDomainSocket(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read from domain socket.
setTotalBytesReadDomainSocketThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read domain socket throughput.
setTotalBytesReadLocal(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read local.
setTotalBytesReadLocalThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read local throughput.
setTotalBytesReadRemote(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read remote.
setTotalBytesReadRemoteThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read remote throughput.
setTotalBytesReadUfs(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read ufs.
setTotalBytesReadUfsThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes read ufs throughput.
setTotalBytesWrittenDomainSocket(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written through domain socket.
setTotalBytesWrittenDomainSocketThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written domain socket throughput.
setTotalBytesWrittenLocal(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written local.
setTotalBytesWrittenLocalThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written local throughput.
setTotalBytesWrittenRemote(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written remote.
setTotalBytesWrittenRemoteThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written remote throughput.
setTotalBytesWrittenUfs(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written ufs.
setTotalBytesWrittenUfsThroughput(String) - Method in class alluxio.wire.MasterWebUIMetrics
Sets total bytes written ufs throughput.
setTotalPath(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets total path.
setTtl(long) - Method in class alluxio.wire.FileInfo
 
setTtlAction(TtlAction) - Method in class alluxio.wire.FileInfo
 
setType(AclEntryType) - Method in class alluxio.security.authorization.AclEntry.Builder
Sets the type of the entry.
setType(String) - Method in class alluxio.job.JobDescription.Builder
set job type.
setUfsCapacity(Capacity) - Method in class alluxio.wire.AlluxioMasterInfo
 
setUfsCapacityBytes(long) - Method in class alluxio.wire.MountPointInfo
 
setUfsFingerprint(String) - Method in class alluxio.wire.FileInfo
 
setUfsLocations(List<String>) - Method in class alluxio.wire.FileBlockInfo
 
setUfsOps(Map<String, Map<String, Long>>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets ufs ops.
setUfsOpsSaved(Map<String, Map<String, Long>>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets ufs saved ops.
setUfsPath(String) - Method in class alluxio.wire.FileInfo
 
setUfsReadSize(Map<String, String>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets ufs read size.
setUfsType(String) - Method in class alluxio.wire.MountPointInfo
 
setUfsUri(String) - Method in class alluxio.wire.MountPointInfo
 
setUfsUsedBytes(long) - Method in class alluxio.wire.MountPointInfo
 
setUfsWriteSize(Map<String, String>) - Method in class alluxio.wire.MasterWebUIMetrics
Sets ufs write size.
setUniqueBlockCount(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets unique block count.
setUptime(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets uptime.
setUptimeMs(long) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setUptimeMs(long) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
setUptimeMs(long) - Method in class alluxio.wire.AlluxioMasterInfo
 
setUptimeMs(long) - Method in class alluxio.wire.AlluxioProxyInfo
 
setUptimeMs(long) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setUri(AlluxioURI) - Method in class alluxio.wire.UfsInfo
 
setUriValidationEnabled(boolean) - Method in class alluxio.ClientContext
 
setUsageOnTiers(List<UIUsageOnTier>) - Method in class alluxio.wire.WorkerWebUIOverview
Sets usage on tiers.
setUsed(long) - Method in class alluxio.wire.Capacity
 
setUsedBytes(long) - Method in class alluxio.wire.BlockMasterInfo
 
setUsedBytes(long) - Method in class alluxio.wire.WorkerInfo
 
setUsedBytes(String) - Method in class alluxio.wire.WorkerWebUIOverview
Sets used bytes.
setUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.BlockMasterInfo
 
setUsedBytesOnTiers(Map<String, Long>) - Method in class alluxio.wire.WorkerInfo
 
setUsedCapacity(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets used capacity.
setUseReservedSpace(boolean) - Method in class alluxio.worker.block.AllocateOptions
Sets value for whether this allocation can use reserved space.
setValue(double) - Method in class alluxio.metrics.Metric
Set the metric value.
setValue(V) - Method in class alluxio.conf.path.TrieNode
Set the value associated with this node.
setValues(Map<Optional<String>, List<String>>) - Method in class alluxio.wire.InconsistentProperty
 
setValueValidationFunction(Function<Object, Boolean>) - Method in class alluxio.conf.PropertyKey.Builder
 
setVersion(String) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioMasterInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioProxyInfo
 
setVersion(String) - Method in class alluxio.wire.AlluxioWorkerInfo
 
setVersion(String) - Method in class alluxio.wire.MasterWebUIOverview
Sets version.
setVersion(String) - Method in class alluxio.wire.WorkerInfo
 
setVersion(String) - Method in class alluxio.wire.WorkerWebUIOverview
Sets version.
setViewingOffset(long) - Method in class alluxio.wire.MasterWebUIBrowse
Sets viewing offset.
setViewingOffset(long) - Method in class alluxio.wire.MasterWebUILogs
Sets viewing offset.
setViewingOffset(long) - Method in class alluxio.wire.WorkerWebUILogs
Sets viewing offset.
setWebFileInfoEnabled(boolean) - Method in class alluxio.wire.MasterWebUIInit
Sets web file info enabled.
setWebFileInfoEnabled(boolean) - Method in class alluxio.wire.WorkerWebUIInit
Sets web file info enabled.
setWebPort(int) - Method in class alluxio.wire.WorkerNetAddress
 
setWhitelist(List<String>) - Method in class alluxio.wire.MasterWebUIConfiguration
Sets whitelist.
setWhitelist(List<String>) - Method in class alluxio.wire.WorkerWebUIConfiguration
Sets whitelist.
setWorkerAddress(WorkerNetAddress) - Method in class alluxio.wire.BlockLocation
 
setWorkerCapacityFreePercentage(long) - Method in class alluxio.wire.WorkerWebUIMetrics
Sets worker capacity free percentage.
setWorkerCapacityUsedPercentage(long) - Method in class alluxio.wire.WorkerWebUIMetrics
Sets worker capacity used percentage.
setWorkerId(long) - Method in class alluxio.wire.BlockLocation
 
setWorkerInfo(UIWorkerInfo) - Method in class alluxio.wire.WorkerWebUIOverview
Sets worker info.
setWorkerPort(int) - Method in class alluxio.wire.MasterWebUIInit
Sets worker port.
setWorkers(List<WorkerInfo>) - Method in class alluxio.wire.AlluxioJobMasterInfo
 
setWorkers(List<WorkerInfo>) - Method in class alluxio.wire.AlluxioMasterInfo
 
setXAttr(Map<String, byte[]>) - Method in class alluxio.wire.FileInfo
 
ShadowCacheType - Enum in alluxio.client.file.cache
This represents the different shadow cache implementations that can be instantiated.
ShellBasedUnixGroupsMapping - Class in alluxio.security.group.provider
A simple shell-based implementation of GroupMappingService that exec's the groups shell command to fetch the group memberships of a given user.
ShellBasedUnixGroupsMapping() - Constructor for class alluxio.security.group.provider.ShellBasedUnixGroupsMapping
Constructs a new ShellBasedUnixGroupsMapping.
ShellCommand - Class in alluxio.shell
Object representation of a shell command.
ShellCommand(String[]) - Constructor for class alluxio.shell.ShellCommand
Creates a ShellCommand object with the command to exec.
ShellUtils - Class in alluxio.util
A utility class for running Unix commands.
ShellUtils.ExitCodeException - Exception in alluxio.util
This is an IOException with exit code added.
shouldGc(DynamicResourcePool.ResourceInternal<Channel>) - Method in class alluxio.network.netty.NettyChannelPool
 
shouldGc(DynamicResourcePool.ResourceInternal<T>) - Method in class alluxio.resource.DynamicResourcePool
 
shouldUseDisplayValue() - Method in class alluxio.conf.ConfigurationValueOptions
 
shouldUseRawValue() - Method in class alluxio.conf.ConfigurationValueOptions
 
shutdown() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Possibly initiates an orderly shutdown in which previously submitted tasks are executed, but no new tasks will be accepted.
shutdown() - Method in class alluxio.grpc.GrpcChannel
Shuts down the channel.
shutdown() - Method in class alluxio.grpc.GrpcServer
Shuts down the server.
shutdown() - Method in class alluxio.metrics.InstrumentedExecutorService
 
shutdown() - Method in class alluxio.util.executor.ControllableScheduler
 
shutdownAndAwaitTermination(ExecutorService) - Static method in class alluxio.util.executor.ExecutorServiceUtils
ShutdownAndAwaitTermination with default timeout.
shutdownAndAwaitTermination(ExecutorService, long) - Static method in class alluxio.util.executor.ExecutorServiceUtils
Gracefully shutdown ExecutorService method.
shutdownAndAwaitTermination(ExecutorService, long) - Static method in class alluxio.util.ThreadUtils
From https://docs.oracle.com/javase/7/docs/api/java/util/concurrent/ExecutorService.html The following method shuts down an ExecutorService in two phases, first by calling shutdown to reject incoming tasks, and then calling shutdownNow, if necessary, to cancel any lingering tasks.
shutdownNow() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Possibly attempts to cancel and/or stop all tasks, and reject all subsequently submitted tasks.
shutdownNow() - Method in class alluxio.metrics.InstrumentedExecutorService
 
shutdownNow() - Method in class alluxio.util.executor.ControllableScheduler
 
SIMPLE - alluxio.security.authentication.AuthType
User is aware in Alluxio.
SimpleAuthenticationProvider - Class in alluxio.security.authentication.plain
An authentication provider implementation that allows arbitrary combination of username and password including empty strings.
SimpleAuthenticationProvider() - Constructor for class alluxio.security.authentication.plain.SimpleAuthenticationProvider
SimpleUserState - Class in alluxio.security.user
UserState implementation for the simple authentication schemes.
SimpleUserState.Factory - Class in alluxio.security.user
Factory class to create the user state.
SINGLE_MASTER_AUTH - Static variable in interface alluxio.uri.Authority
 
singleElementIterator(T) - Static method in class alluxio.util.CommonUtils
Returns an iterator that iterates on a single element.
SingleMasterAuthority - Class in alluxio.uri
A single master authority implementation.
SingleMasterAuthority(String, int) - Constructor for class alluxio.uri.SingleMasterAuthority
 
SingleMasterConnectDetails(InetSocketAddress) - Constructor for class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
SingleMasterInquireClient - Class in alluxio.master
A MasterInquireClient which always returns a fixed master address.
SingleMasterInquireClient(InetSocketAddress) - Constructor for class alluxio.master.SingleMasterInquireClient
 
SingleMasterInquireClient.SingleMasterConnectDetails - Class in alluxio.master
Connect details for a single master inquire client.
SingleTagValueAggregator - Class in alluxio.metrics.aggregator
An aggregator that aggregates the metrics into multiple values based on a single tag of the metric.
SingleTagValueAggregator(String, String, String) - Constructor for class alluxio.metrics.aggregator.SingleTagValueAggregator
Constructs a new instance of SingleTagValueAggregator.
SingleValueAggregator - Interface in alluxio.metrics
Interface for the aggregator that aggregates into a single value from the metrics of different hosts.
Sink - Interface in alluxio.metrics.sink
Sink consumes the records generated by the metrics source.
SINK_REGEX - Static variable in class alluxio.metrics.MetricsSystem
 
SITE_CONF_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
SITE_CONF_DIR - Static variable in class alluxio.conf.PropertyKey
 
SITE_PROPERTIES - Static variable in class alluxio.Constants
 
SITE_PROPERTY - alluxio.conf.Source.Type
The property value is specified in site properties file (alluxio-site.properties).
siteProperty(String) - Static method in class alluxio.conf.Source
Creates a site property source with the specified filename.
size() - Method in interface alluxio.collections.BitSet
 
size() - Method in class alluxio.collections.BuiltinBitSet
 
size() - Method in class alluxio.collections.ConcurrentHashSet
 
size() - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
size() - Method in class alluxio.collections.DelegatingSet
 
size() - Method in interface alluxio.collections.FieldIndex
 
size() - Method in class alluxio.collections.IndexedSet
 
size() - Method in class alluxio.collections.LockPool
 
size() - Method in class alluxio.collections.NonUniqueFieldIndex
 
size() - Method in class alluxio.collections.UniqueFieldIndex
 
size() - Method in class alluxio.collections.UnmodifiableArrayList
 
size() - Method in class alluxio.metrics.MaxReservoir
Returns the number of values recorded.
size() - Method in class alluxio.resource.DynamicResourcePool
 
size() - Method in interface alluxio.resource.Pool
 
size() - Method in class alluxio.resource.ResourcePool
 
size() - Method in interface alluxio.StorageTierAssoc
 
size() - Method in class alluxio.util.executor.UniqueBlockingQueue
 
size(CloseableIterator<?>) - Static method in class alluxio.resource.CloseableIterator
Consumes the iterator, closes it, and returns its size.
skip(long) - Method in class alluxio.file.SeekableBufferedInputStream
 
skip(long) - Method in class alluxio.underfs.MultiRangeObjectInputStream
 
SKIPPED - alluxio.cli.ValidationUtils.State
 
sleep(Duration) - Method in interface alluxio.time.Sleeper
Sleeps for the given duration.
sleep(Duration) - Method in class alluxio.time.ThreadSleeper
 
Sleeper - Interface in alluxio.time
An interface for a utility which provides a sleep method.
SLEEPING_TIMER_CLASS - Static variable in class alluxio.heartbeat.HeartbeatContext
 
SleepingRetry - Class in alluxio.retry
A retry policy that uses thread sleeping for the delay.
SleepingRetry(int) - Constructor for class alluxio.retry.SleepingRetry
 
SleepingTimer - Class in alluxio.heartbeat
This class can be used for executing heartbeats periodically.
SleepingTimer(String, long) - Constructor for class alluxio.heartbeat.SleepingTimer
Creates a new instance of SleepingTimer.
SleepingTimer(String, long, Logger, Clock, Sleeper) - Constructor for class alluxio.heartbeat.SleepingTimer
Creates a new instance of SleepingTimer.
sleepMs(long) - Static method in class alluxio.util.CommonUtils
Sleeps for the given number of milliseconds.
sleepMs(long) - Static method in class alluxio.util.SleepUtils
Sleeps for the given number of milliseconds.
sleepMs(Logger, long) - Static method in class alluxio.util.CommonUtils
Sleeps for the given number of milliseconds, reporting interruptions using the given logger.
sleepMs(Logger, long) - Static method in class alluxio.util.SleepUtils
Sleeps for the given number of milliseconds, reporting interruptions using the given logger.
SleepUtils - Class in alluxio.util
Sleep utilities shared by all components in Alluxio.
Slf4jSink - Class in alluxio.metrics.sink
A sink which outputs metric values to the metrics logger.
Slf4jSink(Properties, MetricRegistry) - Constructor for class alluxio.metrics.sink.Slf4jSink
Creates a new Slf4jSink with a Properties and MetricRegistry.
sliceByteBuffer(ByteBuffer, int) - Static method in class alluxio.util.io.BufferUtils
Convenience method for BufferUtils.sliceByteBuffer(ByteBuffer, int, int) where the last parameter is the number of remaining bytes in the new buffer.
sliceByteBuffer(ByteBuffer, int, int) - Static method in class alluxio.util.io.BufferUtils
Creates a new ByteBuffer sliced from a given ByteBuffer.
SOCKET_TIMEOUT_CONFIG_NAME - Static variable in class alluxio.cli.ValidationConfig
 
SOCKET_TIMEOUT_OPTION_NAME - Static variable in class alluxio.cli.ValidationConfig
 
sortTopologically(Set<T>) - Method in class alluxio.collections.DirectedAcyclicGraph
Sorts a given set of payloads topologically based on the DAG.
Source - Class in alluxio.conf
The source of a configuration property.
Source - Interface in alluxio.metrics.source
Source is where the metrics generated.
Source.Type - Enum in alluxio.conf
Source type.
SPACE_FREE - alluxio.underfs.UnderFileSystem.SpaceType
Indicates the amount of free space available in the under file system.
SPACE_TOTAL - alluxio.underfs.UnderFileSystem.SpaceType
Indicates the storage capacity of the under file system.
SPACE_USED - alluxio.underfs.UnderFileSystem.SpaceType
Indicates the amount of space used in the under file system.
SpecificPathConfiguration - Class in alluxio.conf.path
Configuration for a specific Alluxio path.
SpecificPathConfiguration(AlluxioConfiguration, PathConfiguration, AlluxioURI) - Constructor for class alluxio.conf.path.SpecificPathConfiguration
Constructs a new instance with the specified references without copying the underlying properties.
specifiedMaster(InetSocketAddress) - Static method in class alluxio.master.selectionpolicy.MasterSelectionPolicy.Factory
Creates a MasterSelectionPolicy that selects a specified master to connect.
spliterator() - Method in class alluxio.collections.DelegatingSet
 
SshCommand - Class in alluxio.shell
Object representation of a remote shell command by SSH.
SshCommand(String, String[]) - Constructor for class alluxio.shell.SshCommand
Creates a SshCommand instance from the remote hostname and command.
sshExecCommandWithOutput(String, String...) - Static method in class alluxio.util.ShellUtils
Static method to execute a shell command remotely via ssh.
sslContext(SslContext) - Method in class alluxio.grpc.GrpcServerBuilder
Sets TLS context.
SslContextProvider - Interface in alluxio.util.network.tls
Interface for providing SslContext instances for TLS support.
SslContextProvider.Factory - Class in alluxio.util.network.tls
Factory for creating context provider implementations.
STANDALONE_FUSE_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
STANDALONE_FUSE_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
STANDARD - alluxio.master.ZookeeperConnectionErrorPolicy
 
StandardURI - Class in alluxio.uri
A standard URI implementation.
StandardURI(URI, String) - Constructor for class alluxio.uri.StandardURI
Constructs a new URI from a base URI, but with a new path component.
StandardURI(String, Authority, String, String) - Constructor for class alluxio.uri.StandardURI
 
STANDBY_MASTER_METRICS_SINK_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
STANDBY_MASTER_METRICS_SINK_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
STANDBY_MASTER_WEB_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
STANDBY_MASTER_WEB_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
start() - Method in class alluxio.grpc.GrpcServer
Start serving.
start() - Method in class alluxio.metrics.sink.ConsoleSink
 
start() - Method in class alluxio.metrics.sink.CsvSink
 
start() - Method in class alluxio.metrics.sink.GraphiteSink
 
start() - Method in class alluxio.metrics.sink.JmxSink
 
start() - Method in interface alluxio.metrics.sink.Sink
Starts the reporter polling.
start() - Method in class alluxio.metrics.sink.Slf4jSink
 
start() - Method in class alluxio.util.JvmPauseMonitor
Starts jvm monitor thread.
start(T) - Method in interface alluxio.Server
Starts the Alluxio server.
START_AFTER_DOES_NOT_MATCH_PATH - alluxio.exception.ExceptionMessage
 
startActiveSyncPolling(long) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
startActiveSyncPolling(long) - Method in class alluxio.underfs.BaseUnderFileSystem
 
startActiveSyncPolling(long) - Method in interface alluxio.underfs.UnderFileSystem
Start Active Sync.
startActiveSyncPolling(long) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
startAuthenticatedChannel(long) - Method in class alluxio.security.authentication.AuthenticatedChannelClientDriver
Starts authentication with the server and wait until completion.
startSinks(String) - Static method in class alluxio.metrics.MetricsSystem
Starts sinks specified in the configuration.
startSinksFromConfig(MetricsConfig) - Static method in class alluxio.metrics.MetricsSystem
Starts sinks from a given metrics configuration.
startsWithIncreasingByteArray(int, int, byte[]) - Static method in class alluxio.util.io.BufferUtils
Checks if the given byte array contains an increasing sequence of bytes of the given length, starting from the given value.
startSync(AlluxioURI) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
startSync(AlluxioURI) - Method in class alluxio.underfs.BaseUnderFileSystem
 
startSync(AlluxioURI) - Method in interface alluxio.underfs.UnderFileSystem
Add Sync Point.
startSync(AlluxioURI) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
STATE_LOCK_TIMED_OUT - alluxio.exception.ExceptionMessage
 
stop() - Method in class alluxio.metrics.sink.ConsoleSink
 
stop() - Method in class alluxio.metrics.sink.CsvSink
 
stop() - Method in class alluxio.metrics.sink.GraphiteSink
 
stop() - Method in class alluxio.metrics.sink.JmxSink
 
stop() - Method in interface alluxio.metrics.sink.Sink
Stops the reporter.
stop() - Method in class alluxio.metrics.sink.Slf4jSink
 
stop() - Method in interface alluxio.Server
Stops the Alluxio server.
stop() - Method in class alluxio.util.JvmPauseMonitor
Stops jvm monitor.
stopActiveSyncPolling() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
stopActiveSyncPolling() - Method in class alluxio.underfs.BaseUnderFileSystem
 
stopActiveSyncPolling() - Method in interface alluxio.underfs.UnderFileSystem
Stop Active Sync.
stopActiveSyncPolling() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
stopAndJoin() - Method in class alluxio.network.RejectingServer
Stops the server and joins the server thread.
stopSinks() - Static method in class alluxio.metrics.MetricsSystem
Stops all the sinks.
stopSync(AlluxioURI) - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
stopSync(AlluxioURI) - Method in class alluxio.underfs.BaseUnderFileSystem
 
stopSync(AlluxioURI) - Method in interface alluxio.underfs.UnderFileSystem
Stop Sync Point.
stopSync(AlluxioURI) - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
StorageDir - Interface in alluxio.worker.block.meta
Represents a directory in a storage tier.
StorageTier - Interface in alluxio.worker.block.meta
Represents a tier of storage, for example memory or SSD.
StorageTierAssoc - Interface in alluxio
A two-way mapping between storage tier aliases and ordinal numbers from configuration.
StorageTierInfo - Class in alluxio.util.webui
Class to make referencing tiered storage information more intuitive.
StorageTierInfo(String, long, long) - Constructor for class alluxio.util.webui.StorageTierInfo
Instantiates a new Storage tier info.
STORE - alluxio.client.AlluxioStorageType
Put the data reading or writing in Alluxio storage.
stream() - Method in class alluxio.collections.DelegatingSet
 
stream(T) - Method in class alluxio.grpc.DataMessageMarshaller
 
STREAMING - alluxio.grpc.GrpcNetworkGroup
Networking group for Streaming traffic.
StreamUtils - Class in alluxio.util
Convenience methods for working with streams.
STRING - alluxio.conf.PropertyKey.PropertyType
The Property's value is of string type, stored as a String.
STRING_ENTRY_FIELD - Static variable in class alluxio.security.authorization.AccessControlList
 
stringBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
stripInstanceAndHost(String) - Static method in class alluxio.metrics.MetricsSystem
Removes the instance and host from the given metric name, returning the result.
stripLeadingAndTrailingQuotes(String) - Static method in class alluxio.util.CommonUtils
Strips the leading and trailing quotes from the given string.
stripPrefixIfPresent(String) - Method in class alluxio.underfs.ObjectUnderFileSystem
Strips the bucket prefix or the preceding path separator from the path if it is present.
stripPrefixIfPresent(String, String) - Static method in class alluxio.util.CommonUtils
Strips the prefix from the key if it is present.
stripSuffixIfPresent(String, String) - Static method in class alluxio.util.CommonUtils
Strips the suffix if it exists.
subList(int, int) - Method in class alluxio.collections.UnmodifiableArrayList
 
submit(ForkJoinTask<T>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
Submits a ForkJoinTask for execution.
submit(Runnable) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
submit(Runnable) - Method in class alluxio.metrics.InstrumentedExecutorService
 
submit(Runnable) - Method in class alluxio.util.executor.ControllableScheduler
 
submit(Runnable, T) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
submit(Runnable, T) - Method in class alluxio.metrics.InstrumentedExecutorService
 
submit(Runnable, T) - Method in class alluxio.util.executor.ControllableScheduler
 
submit(Callable<T>) - Method in class alluxio.concurrent.jsr.ForkJoinPool
 
submit(Callable<T>) - Method in class alluxio.metrics.InstrumentedExecutorService
 
submit(Callable<T>) - Method in class alluxio.util.executor.ControllableScheduler
 
subProperties(Properties, String) - Static method in class alluxio.metrics.MetricsConfig
Uses regex to parse every original property key to a prefix and a suffix.
subtractPaths(String, String) - Static method in class alluxio.util.io.PathUtils
Removes the prefix from the path, yielding a relative path from the second path to the first.
summarizeCollection(Object) - Static method in class alluxio.util.CommonUtils
 
supplyAsync(Supplier<U>) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is asynchronously completed by a task running in the ForkJoinPool.commonPool() with the value obtained by calling the given Supplier.
supplyAsync(Supplier<U>, Executor) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is asynchronously completed by a task running in the given executor with the value obtained by calling the given Supplier.
supportsActiveSync() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
supportsActiveSync() - Method in class alluxio.underfs.BaseUnderFileSystem
 
supportsActiveSync() - Method in interface alluxio.underfs.UnderFileSystem
Whether this type of UFS supports active sync.
supportsActiveSync() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
supportsFlush() - Method in class alluxio.concurrent.ManagedBlockingUfsForwarder
 
supportsFlush() - Method in class alluxio.underfs.ObjectUnderFileSystem
 
supportsFlush() - Method in interface alluxio.underfs.UnderFileSystem
Whether this type of UFS supports flush.
supportsFlush() - Method in class alluxio.underfs.UnderFileSystemWithLogging
 
supportsPath(String) - Method in interface alluxio.underfs.UnderFileSystemFactory
Gets whether this factory supports the given path and thus whether calling the UnderFileSystemFactory.create(String, UnderFileSystemConfiguration) can succeed for this path.
supportsPath(String, UnderFileSystemConfiguration) - Method in interface alluxio.underfs.UnderFileSystemFactory
Gets whether this factory supports the given path and thus whether calling the UnderFileSystemFactory.create(String, UnderFileSystemConfiguration) can succeed for this path.
supportsPath(String, S) - Method in interface alluxio.extensions.ExtensionFactory
Gets whether this factory supports the given path and thus whether calling the #create(String, S) can succeed for this path.
SuppressFBWarnings - Annotation Type in alluxio.annotation
Suppresses warnings by findbugs-maven-plugin.
SWIFT_AUTH_KEYSTONE - Static variable in class alluxio.Constants
 
SWIFT_AUTH_KEYSTONE_V3 - Static variable in class alluxio.Constants
 
SWIFT_AUTH_METHOD_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_AUTH_METHOD_KEY - Static variable in class alluxio.conf.PropertyKey
 
SWIFT_AUTH_SWIFTAUTH - Static variable in class alluxio.Constants
 
SWIFT_AUTH_URL_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_AUTH_URL_KEY - Static variable in class alluxio.conf.PropertyKey
 
SWIFT_PASSWORD_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_PASSWORD_KEY - Static variable in class alluxio.conf.PropertyKey
 
SWIFT_REGION_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_REGION_KEY - Static variable in class alluxio.conf.PropertyKey
 
SWIFT_SIMULATION - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_SIMULATION - Static variable in class alluxio.conf.PropertyKey
 
SWIFT_TENANT_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_TENANT_KEY - Static variable in class alluxio.conf.PropertyKey
 
SWIFT_USER_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
SWIFT_USER_KEY - Static variable in class alluxio.conf.PropertyKey
 
SYNC_PERSIST - alluxio.client.UnderStorageType
Persist data to the under storage synchronously.
SYNCHRONOUS_BLOCKING_QUEUE - alluxio.executor.ThreadPoolExecutorQueueType
ArrayBlockingQueue.
SyncInfo - Class in alluxio
This class is used to represent what the active syncing process should sync.
SyncInfo(Map<AlluxioURI, Set<AlluxioURI>>, boolean, long) - Constructor for class alluxio.SyncInfo
Constructs a SyncInfo.
SYNCING - alluxio.wire.SyncPointInfo.SyncStatus
 
SyncPointInfo - Class in alluxio.wire
This class represents the state of a sync point, whether the intial syncing is done, in progress or not going to be done.
SyncPointInfo(AlluxioURI, SyncPointInfo.SyncStatus) - Constructor for class alluxio.wire.SyncPointInfo
Constructs a SyncPointInfo object.
SyncPointInfo.SyncStatus - Enum in alluxio.wire
Indicates the status of the initial sync of the active sync point.
SYSTEM - alluxio.master.file.meta.xattr.ExtendedAttribute.NamespacePrefix
 
SYSTEM - Static variable in class alluxio.time.TimeContext
 
SYSTEM_PROPERTY - alluxio.conf.Source.Type
The property value is specified with JVM -D options before passed to Alluxio.
SYSTEM_PROPERTY - Static variable in class alluxio.conf.Source
 
SystemClock - Class in alluxio.clock
A clock representing the current time as reported by the operating system.
SystemClock() - Constructor for class alluxio.clock.SystemClock
Constructs a new Clock which reports the actual time.

T

TABLE - alluxio.client.quota.CacheScope.Level
 
TABLE_ALREADY_TRANSFORMED - alluxio.exception.ExceptionMessage
 
TABLE_BEING_TRANSFORMED - alluxio.exception.ExceptionMessage
 
TABLE_CATALOG_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_CATALOG_PATH - Static variable in class alluxio.conf.PropertyKey
 
TABLE_CATALOG_UDB_SYNC_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_CATALOG_UDB_SYNC_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
TABLE_DOES_NOT_EXIST - alluxio.exception.ExceptionMessage
 
TABLE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
TABLE_JOURNAL_PARTITIONS_CHUNK_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_JOURNAL_PARTITIONS_CHUNK_SIZE - Static variable in class alluxio.conf.PropertyKey
 
TABLE_LOAD_DEFAULT_REPLICATION - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_LOAD_DEFAULT_REPLICATION - Static variable in class alluxio.conf.PropertyKey
 
TABLE_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
TABLE_MASTER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
TABLE_MASTER_NAME - Static variable in class alluxio.Constants
 
TABLE_TRANSFORM_MANAGER_JOB_HISTORY_RETENTION_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_TRANSFORM_MANAGER_JOB_HISTORY_RETENTION_TIME - Static variable in class alluxio.conf.PropertyKey
 
TABLE_TRANSFORM_MANAGER_JOB_MONITOR_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_TRANSFORM_MANAGER_JOB_MONITOR_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
TABLE_UDB_HIVE_CLIENTPOOL_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_UDB_HIVE_CLIENTPOOL_MAX - Static variable in class alluxio.conf.PropertyKey
 
TABLE_UDB_HIVE_CLIENTPOOL_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
TABLE_UDB_HIVE_CLIENTPOOL_MIN - Static variable in class alluxio.conf.PropertyKey
 
TABLES_CONFIG_NAME - Static variable in class alluxio.cli.ValidationConfig
 
TABLES_OPTION_NAME - Static variable in class alluxio.cli.ValidationConfig
 
TAG_SEPARATOR - Static variable in class alluxio.metrics.Metric
 
TAG_UFS - Static variable in class alluxio.metrics.MetricInfo
 
TAG_UFS_TYPE - Static variable in class alluxio.metrics.MetricInfo
 
TAG_USER - Static variable in class alluxio.metrics.MetricInfo
 
take() - Method in class alluxio.util.executor.UniqueBlockingQueue
 
takeRecords() - Method in class alluxio.recorder.NoopRecorder
 
takeRecords() - Method in class alluxio.recorder.Recorder
Gets and clears the records recorded so far.
TB - Static variable in class alluxio.Constants
 
TEMP_BLOCK_ID_COMMITTED - alluxio.exception.ExceptionMessage
 
TEMP_BLOCK_META_NOT_FOUND - alluxio.exception.ExceptionMessage
 
TempBlockMeta - Interface in alluxio.worker.block.meta
Represents the metadata of an uncommitted block in Alluxio managed storage.
TempBlockMetaFactory - Interface in alluxio.worker.block
Factory for TempBlockMeta.
temporaryFileName(long, String) - Static method in class alluxio.util.io.PathUtils
Generates a deterministic temporary file name for the a path and a file id and a nonce.
TEST_ARTIFACTS_DIR - Static variable in class alluxio.Constants
 
TEST_DEPRECATED_KEY - Static variable in class alluxio.conf.PropertyKey
Deprecated.
This key is used for testing. It is always deprecated.
TEST_DEPRECATED_TEMPLATE - alluxio.conf.PropertyKey.Template
Deprecated.
This template is always deprecated. It is used only for testing.
TEST_LOG_DIR - Static variable in class alluxio.Constants
 
TEST_MODE - Static variable in class alluxio.conf.PropertyKey.Name
 
TEST_MODE - Static variable in class alluxio.conf.PropertyKey
 
testAllCornerCases() - Method in class alluxio.PositionReaderTest
Tests all corner cases.
testReadRandomPart() - Method in class alluxio.PositionReaderTest
Tests read random parts.
TESTS_LOG - Static variable in class alluxio.Constants
 
thenAccept(Consumer<? super T>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenAccept(Consumer<? super T>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, is executed with this stage's result as the argument to the supplied action.
thenAcceptAsync(Consumer<? super T>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenAcceptAsync(Consumer<? super T>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, is executed using this stage's default asynchronous execution facility, with this stage's result as the argument to the supplied action.
thenAcceptAsync(Consumer<? super T>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenAcceptAsync(Consumer<? super T>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, is executed using the supplied Executor, with this stage's result as the argument to the supplied action.
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenAcceptBoth(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, is executed with the two results as arguments to the supplied action.
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, is executed using this stage's default asynchronous execution facility, with the two results as arguments to the supplied action.
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenAcceptBothAsync(CompletionStage<? extends U>, BiConsumer<? super T, ? super U>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, is executed using the supplied executor, with the two results as arguments to the supplied action.
thenApply(Function<? super T, ? extends U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenApply(Function<? super T, ? extends U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, is executed with this stage's result as the argument to the supplied function.
thenApplyAsync(Function<? super T, ? extends U>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenApplyAsync(Function<? super T, ? extends U>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, is executed using this stage's default asynchronous execution facility, with this stage's result as the argument to the supplied function.
thenApplyAsync(Function<? super T, ? extends U>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenApplyAsync(Function<? super T, ? extends U>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, is executed using the supplied Executor, with this stage's result as the argument to the supplied function.
thenCombine(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenCombine(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, is executed with the two results as arguments to the supplied function.
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, is executed using this stage's default asynchronous execution facility, with the two results as arguments to the supplied function.
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenCombineAsync(CompletionStage<? extends U>, BiFunction<? super T, ? super U, ? extends V>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this and the other given stage both complete normally, is executed using the supplied executor, with the two results as arguments to the supplied function.
thenCompose(Function<? super T, ? extends CompletionStage<U>>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenCompose(Function<? super T, ? extends CompletionStage<U>>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that is completed with the same value as the CompletionStage returned by the given function.
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that is completed with the same value as the CompletionStage returned by the given function, executed using this stage's default asynchronous execution facility.
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenComposeAsync(Function<? super T, ? extends CompletionStage<U>>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that is completed with the same value as the CompletionStage returned by the given function, executed using the supplied Executor.
thenRun(Runnable) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenRun(Runnable) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, executes the given action.
thenRunAsync(Runnable) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenRunAsync(Runnable) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, executes the given action using this stage's default asynchronous execution facility.
thenRunAsync(Runnable, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
thenRunAsync(Runnable, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage that, when this stage completes normally, executes the given action using the supplied Executor.
ThreadFactoryUtils - Class in alluxio.util
Utility methods for the ThreadFactory class.
ThreadPoolExecutorQueueType - Enum in alluxio.executor
Internal task queue type for ThreadPoolExecutor.
ThreadSleeper - Class in alluxio.time
A sleeping utility which delegates to Thread.sleep().
ThreadUtils - Class in alluxio.util
Utility method for working with threads.
THROTTLE_MASTER_NAME - Static variable in class alluxio.Constants
 
THROUGH - alluxio.client.WriteType
Write the file synchronously to the under fs, skipping Alluxio storage.
tick() - Method in interface alluxio.heartbeat.HeartbeatTimer
Waits until next heartbeat should be executed.
tick() - Method in class alluxio.heartbeat.ScheduledTimer
 
tick() - Method in class alluxio.heartbeat.SleepingTimer
Enforces the thread waits for the given interval between consecutive ticks.
tick() - Method in class alluxio.time.ExponentialTimer
Attempts to perform a timer tick.
tick(long) - Method in class alluxio.util.executor.ControllableQueue
Jumps to a future time period.
TIER - Static variable in class alluxio.metrics.MetricInfo
 
TIER_ALIAS_NOT_FOUND - alluxio.exception.ExceptionMessage
 
TIER_VIEW_ALIAS_NOT_FOUND - alluxio.exception.ExceptionMessage
 
tierAlias() - Method in class alluxio.worker.block.BlockStoreLocation
Gets the storage tier alias of the location.
TieredIdentity - Class in alluxio.wire
Class representing a node's tier identity.
TieredIdentity(List<TieredIdentity.LocalityTier>) - Constructor for class alluxio.wire.TieredIdentity
 
TieredIdentity.LocalityTier - Class in alluxio.wire
Class representing a locality tier, e.g.
TieredIdentityFactory - Class in alluxio.network
Class for getting tiered identity.
TieredIdentityFactory() - Constructor for class alluxio.network.TieredIdentityFactory
 
TieredIdentityUtils - Class in alluxio.util
Utility functions for working with tiered identity.
TimeBoundedRetry - Class in alluxio.retry
Retry mechanism which performs retries until a certain period of time has elapsed.
TimeBoundedRetry(TimeContext, Duration) - Constructor for class alluxio.retry.TimeBoundedRetry
 
TimeContext - Class in alluxio.time
Context for managing time.
TimeContext(Clock, Sleeper) - Constructor for class alluxio.time.TimeContext
 
timeout() - Method in class alluxio.SessionInfo
Checks whether the session has timed out.
TIMEOUT - alluxio.master.GraceMode
 
TimeoutRefresh - Class in alluxio.refresh
A refresh policy which allows refreshing after a specified timeout is reached.
TimeoutRefresh(long) - Constructor for class alluxio.refresh.TimeoutRefresh
Constructs a refresh facility which allows refreshing after a specified timeout is reached.
TimeoutRetry - Class in alluxio.retry
A retry policy which allows retrying until a specified timeout is reached.
TimeoutRetry(long, int) - Constructor for class alluxio.retry.TimeoutRetry
Constructs a retry facility which allows retrying until a specified timeout is reached.
timer(String) - Static method in class alluxio.metrics.MetricsSystem
Get or add timer with the given name.
TimeSeries - Class in alluxio.metrics
Represents a time series which can be graphed in the UI.
TimeSeries(String) - Constructor for class alluxio.metrics.TimeSeries
Create a new time series with the given name and no data.
TimeSeries.DataPoint - Class in alluxio.metrics
Represents a datapoint in a time series.
TMP_DIRS - Static variable in class alluxio.conf.PropertyKey.Name
 
TMP_DIRS - Static variable in class alluxio.conf.PropertyKey
 
TO_BE_PERSISTED - alluxio.master.file.meta.PersistenceState
 
toAclActions() - Method in enum alluxio.security.authorization.Mode.Bits
 
toAclActionSet() - Method in enum alluxio.security.authorization.Mode.Bits
 
toAlluxioException() - Method in exception alluxio.exception.status.AlluxioStatusException
 
toArray() - Method in class alluxio.collections.ConcurrentHashSet
 
toArray() - Method in class alluxio.collections.DelegatingSet
 
toArray() - Method in class alluxio.collections.UnmodifiableArrayList
 
toArray(E[]) - Method in class alluxio.collections.ConcurrentHashSet
 
toArray(T1[]) - Method in class alluxio.collections.DelegatingSet
 
toArray(T1[]) - Method in class alluxio.collections.UnmodifiableArrayList
 
toAuthority() - Method in interface alluxio.master.MasterInquireClient.ConnectDetails
 
toAuthority() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
toAuthority() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
toAuthority() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
toBlockStoreLocation() - Method in interface alluxio.worker.block.meta.StorageDir
 
toByteArray() - Method in class alluxio.util.proto.ProtoMessage
 
toByteArray(long, long) - Static method in class alluxio.master.metastore.rocks.RocksUtils
 
toByteArray(long, String) - Static method in class alluxio.master.metastore.rocks.RocksUtils
 
toCliString() - Method in class alluxio.security.authorization.AclActions
 
toCliString() - Method in class alluxio.security.authorization.AclEntry
 
toCliString() - Method in enum alluxio.security.authorization.AclEntryType
 
toCompletableFuture() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns this CompletableFuture.
toCompletableFuture() - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a CompletableFuture maintaining the same completion properties as this stage.
toDefault(String) - Static method in class alluxio.security.authorization.AclEntry
Convert a normal ACL to a string representing a default ACL.
toFsProto() - Method in class alluxio.wire.OperationId
 
toGetStatusOptions(ExistsPOptions) - Static method in class alluxio.grpc.GrpcUtils
Converts from proto type to options.
toGrpcStatusException() - Method in exception alluxio.exception.runtime.AlluxioRuntimeException
 
toGrpcStatusException() - Method in exception alluxio.exception.status.AlluxioStatusException
 
toGrpcStatusRuntimeException() - Method in exception alluxio.exception.runtime.AlluxioRuntimeException
 
toIOException() - Method in exception alluxio.exception.JournalClosedException
 
toJournalClosedException() - Method in exception alluxio.exception.JournalClosedException.IOJournalClosedException
 
toJournalProto() - Method in class alluxio.wire.OperationId
 
toJson() - Method in interface alluxio.util.JsonSerializable
 
toJson(ValidationResults) - Static method in interface alluxio.cli.ValidationTool
Convert to Json format of the validation result.
TOKEN_SEPARATOR_REGEX - Static variable in class alluxio.util.ShellUtils
Token separator regex used to parse Shell tool outputs.
toLower(char) - Static method in class alluxio.util.URIUtils
 
toMap() - Method in interface alluxio.conf.AlluxioConfiguration
 
toMap() - Static method in class alluxio.conf.Configuration
 
toMap(ConfigurationValueOptions) - Method in interface alluxio.conf.AlluxioConfiguration
 
toMap(ConfigurationValueOptions) - Static method in class alluxio.conf.Configuration
 
toMap(ConfigurationValueOptions) - Method in class alluxio.conf.InstancedConfiguration
 
toMap(ConfigurationValueOptions) - Method in class alluxio.conf.path.SpecificPathConfiguration
 
toMap(ConfigurationValueOptions) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
toModeBits() - Method in class alluxio.security.authorization.AclActions
 
toProto() - Method in enum alluxio.client.ReadType
 
toProto() - Method in enum alluxio.client.WriteType
 
toProto() - Method in class alluxio.metrics.Metric
 
toProto() - Method in enum alluxio.security.authorization.Mode.Bits
 
toProto() - Method in class alluxio.security.authorization.Mode
 
toProto() - Method in class alluxio.wire.Address
 
toProto() - Method in class alluxio.wire.BackupStatus
 
toProto() - Method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 
toProto() - Method in class alluxio.wire.BlockMasterInfo
 
toProto() - Method in class alluxio.wire.ConfigCheckReport
 
toProto() - Method in class alluxio.wire.ConfigHash
 
toProto() - Method in class alluxio.wire.Configuration
 
toProto() - Method in class alluxio.wire.InconsistentProperty
 
toProto() - Method in class alluxio.wire.Property
 
toProto() - Method in class alluxio.wire.SyncPointInfo
 
toProto() - Method in class alluxio.worker.block.BlockStoreLocation
Fill BlockStoreLocationproto with location information.
toProto(long, Optional<RegisterLease>) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(DescendantType) - Static method in class alluxio.grpc.GrpcUtils
Converts options to proto type.
toProto(SetAclAction) - Static method in class alluxio.util.proto.ProtoUtils
Converts wire type to proto type.
toProto(AccessControlList) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(AccessControlList) - Static method in class alluxio.util.proto.ProtoUtils
 
toProto(AclAction) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(AclAction) - Static method in class alluxio.util.proto.ProtoUtils
 
toProto(AclActions) - Static method in class alluxio.util.proto.ProtoUtils
 
toProto(AclEntry) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(AclEntry) - Static method in class alluxio.util.proto.ProtoUtils
 
toProto(AclEntryType) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(AclEntryType) - Static method in class alluxio.util.proto.ProtoUtils
 
toProto(DefaultAccessControlList) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(BlockInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(BlockLocation) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(CommandType) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(FileBlockInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(FileInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts a wire type to a proto type.
toProto(FileSystemCommand) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(LoadMetadataType) - Static method in class alluxio.grpc.GrpcUtils
Converts options to proto type.
toProto(MountPointInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(PersistFile) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(TieredIdentity) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(TieredIdentity.LocalityTier) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(UfsInfo) - Static method in class alluxio.grpc.GrpcUtils
 
toProto(WorkerInfo) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(WorkerNetAddress) - Static method in class alluxio.grpc.GrpcUtils
Converts wire type to proto type.
toProto(Status) - Static method in class alluxio.network.protocol.RPCProtoMessage
Converts an internal exception status to a protocol buffer type status.
toProto(Status) - Static method in class alluxio.util.proto.ProtoUtils
Converts an internal exception status to a protocol buffer type status.
topTiersMatch(TieredIdentity) - Method in class alluxio.wire.TieredIdentity
 
toShort() - Method in class alluxio.security.authorization.Mode
Encodes the object as a short.
toString() - Method in class alluxio.AlluxioURI
Illegal characters unescaped in the string, for glob processing, etc.
toString() - Method in class alluxio.cli.ValidationTaskResult
 
toString() - Method in class alluxio.client.file.CacheContext
 
toString() - Method in class alluxio.client.file.URIStatus
 
toString() - Method in class alluxio.client.hive.HiveCacheContext
 
toString() - Method in class alluxio.client.quota.CacheScope
 
toString() - Method in class alluxio.collections.ConcurrentHashSet
 
toString() - Method in class alluxio.collections.LockPool
 
toString() - Method in class alluxio.collections.Pair
 
toString() - Method in class alluxio.collections.PrefixList
Print out all prefixes separated by ";".
toString() - Method in class alluxio.concurrent.jsr.CompletableFuture
Returns a string identifying this CompletableFuture, as well as its completion state.
toString() - Method in class alluxio.concurrent.jsr.ForkJoinPool
Returns a string identifying this pool, as well as its state, including indications of run state, parallelism level, and worker and task counts.
toString() - Method in class alluxio.conf.PropertyKey.Builder
 
toString() - Method in enum alluxio.conf.PropertyKey.Template
 
toString() - Method in class alluxio.conf.PropertyKey
 
toString() - Method in class alluxio.conf.Source
 
toString() - Method in exception alluxio.exception.AggregateException
 
toString() - Method in enum alluxio.exception.PreconditionMessage
 
toString() - Method in class alluxio.grpc.GrpcChannelKey
 
toString() - Method in class alluxio.grpc.GrpcServer
 
toString() - Method in class alluxio.grpc.GrpcServerAddress
 
toString() - Method in class alluxio.job.CopyJobRequest
 
toString() - Method in class alluxio.job.JobDescription
 
toString() - Method in class alluxio.job.LoadJobRequest
 
toString() - Method in enum alluxio.master.file.meta.xattr.ExtendedAttribute.NamespacePrefix
 
toString() - Method in class alluxio.master.PollingMasterInquireClient.MultiMasterConnectDetails
 
toString() - Method in class alluxio.master.SingleMasterInquireClient.SingleMasterConnectDetails
 
toString() - Method in class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
toString() - Method in class alluxio.metrics.Metric
 
toString() - Method in enum alluxio.metrics.MetricInfo.UfsOps
 
toString() - Method in class alluxio.metrics.MetricKey
 
toString() - Method in class alluxio.metrics.MetricsConfig
 
toString() - Method in class alluxio.metrics.MetricsFilter
 
toString() - Method in enum alluxio.metrics.MetricsSystem.InstanceType
 
toString() - Method in class alluxio.network.protocol.RPCProtoMessage
 
toString() - Method in class alluxio.security.authentication.AuthenticatedUserInfo
 
toString() - Method in class alluxio.security.authorization.AccessControlList
 
toString() - Method in class alluxio.security.authorization.AclActions
 
toString() - Method in class alluxio.security.authorization.AclEntry
 
toString() - Method in enum alluxio.security.authorization.Mode.Bits
 
toString() - Method in class alluxio.security.authorization.Mode
 
toString() - Method in class alluxio.security.CurrentUser
 
toString() - Method in class alluxio.security.User
 
toString() - Method in class alluxio.SessionInfo
 
toString() - Method in class alluxio.shell.ShellCommand
Converts the command to string repr.
toString() - Method in class alluxio.underfs.options.CreateOptions
 
toString() - Method in class alluxio.underfs.options.DeleteOptions
 
toString() - Method in class alluxio.underfs.options.FileLocationOptions
 
toString() - Method in class alluxio.underfs.options.ListOptions
 
toString() - Method in class alluxio.underfs.options.MkdirsOptions
 
toString() - Method in class alluxio.underfs.options.OpenOptions
 
toString() - Method in class alluxio.underfs.UfsDirectoryStatus
 
toString() - Method in class alluxio.underfs.UfsFileStatus
 
toString() - Method in class alluxio.underfs.UnderFileSystemWithLogging.UfsCallable
 
toString() - Method in class alluxio.uri.EmbeddedLogicalAuthority
 
toString() - Method in class alluxio.uri.MultiMasterAuthority
 
toString() - Method in class alluxio.uri.NoAuthority
 
toString() - Method in class alluxio.uri.SingleMasterAuthority
 
toString() - Method in class alluxio.uri.UnknownAuthority
 
toString() - Method in class alluxio.uri.ZookeeperAuthority
 
toString() - Method in class alluxio.uri.ZookeeperLogicalAuthority
 
toString() - Method in class alluxio.util.executor.ControllableQueue
 
toString() - Method in class alluxio.util.proto.ProtoMessage
 
toString() - Method in exception alluxio.util.ShellUtils.ExitCodeException
 
toString() - Method in class alluxio.util.UnixMountInfo.Options
 
toString() - Method in class alluxio.util.UnixMountInfo
 
toString() - Method in class alluxio.util.WaitForOptions
 
toString() - Method in class alluxio.wire.Address
 
toString() - Method in class alluxio.wire.AlluxioJobMasterInfo
 
toString() - Method in class alluxio.wire.AlluxioJobWorkerInfo
 
toString() - Method in class alluxio.wire.AlluxioMasterInfo
 
toString() - Method in class alluxio.wire.AlluxioProxyInfo
 
toString() - Method in class alluxio.wire.AlluxioWorkerInfo
 
toString() - Method in class alluxio.wire.BackupStatus
 
toString() - Method in class alluxio.wire.BlockInfo
 
toString() - Method in class alluxio.wire.BlockLocation
 
toString() - Method in class alluxio.wire.BlockMasterInfo
 
toString() - Method in class alluxio.wire.BlockReadRequest
 
toString() - Method in class alluxio.wire.Capacity
 
toString() - Method in class alluxio.wire.FileBlockInfo
 
toString() - Method in class alluxio.wire.FileInfo
 
toString() - Method in class alluxio.wire.InconsistentProperty
 
toString() - Method in class alluxio.wire.JournalDiskInfo
 
toString() - Method in class alluxio.wire.LogInfo
 
toString() - Method in class alluxio.wire.MasterInfo
 
toString() - Method in class alluxio.wire.MasterWebUIBrowse
 
toString() - Method in class alluxio.wire.MasterWebUIConfiguration
 
toString() - Method in class alluxio.wire.MasterWebUIData
 
toString() - Method in class alluxio.wire.MasterWebUIInit
 
toString() - Method in class alluxio.wire.MasterWebUILogs
 
toString() - Method in class alluxio.wire.MasterWebUIMasters
 
toString() - Method in class alluxio.wire.MasterWebUIMetrics
 
toString() - Method in class alluxio.wire.MasterWebUIMountTable
 
toString() - Method in class alluxio.wire.MasterWebUIOverview
 
toString() - Method in class alluxio.wire.MasterWebUIWorkers
 
toString() - Method in class alluxio.wire.MountPointInfo
 
toString() - Method in class alluxio.wire.RegisterLease
 
toString() - Method in class alluxio.wire.TieredIdentity.LocalityTier
 
toString() - Method in class alluxio.wire.TieredIdentity
 
toString() - Method in class alluxio.wire.WorkerInfo
 
toString() - Method in class alluxio.wire.WorkerNetAddress
 
toString() - Method in class alluxio.wire.WorkerWebUIBlockInfo
 
toString() - Method in class alluxio.wire.WorkerWebUIConfiguration
 
toString() - Method in class alluxio.wire.WorkerWebUIInit
 
toString() - Method in class alluxio.wire.WorkerWebUILogs
 
toString() - Method in class alluxio.wire.WorkerWebUIMetrics
 
toString() - Method in class alluxio.wire.WorkerWebUIOverview
 
toString() - Method in class alluxio.worker.block.AllocateOptions
 
toString() - Method in class alluxio.worker.block.BlockStoreLocation
Converts the location to a human readable form.
toString() - Method in class alluxio.worker.block.CreateBlockOptions
 
toString() - Method in class alluxio.worker.block.io.BlockClient
 
toString() - Method in class alluxio.worker.block.io.DelegatingBlockReader
 
toStringArray(ArrayList<String>) - Static method in class alluxio.util.CommonUtils
Parses ArrayList<String> into String[].
toStringEntries() - Method in class alluxio.security.authorization.AccessControlList
 
toStringHelper() - Method in class alluxio.underfs.UfsStatus
 
TOTAL_EXTRA_TIME - Static variable in class alluxio.metrics.MetricKey.Name
 
TOTAL_EXTRA_TIME - Static variable in class alluxio.metrics.MetricKey
 
touch(UnderFileSystem, String) - Static method in class alluxio.util.UnderFileSystemUtils
Creates an empty file.
toUserPropertyMap(ConfigurationValueOptions) - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
TPE - alluxio.executor.RpcExecutorType
 
trace(String) - Method in class alluxio.util.logging.SamplingLogger
 
trace(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
trace(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
trace(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
trace(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
trace(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
transfer(ReadableByteChannel, WritableByteChannel) - Static method in class alluxio.util.io.BufferUtils
An efficient copy between two channels with a fixed-size buffer.
TRANSFER - alluxio.network.netty.FileTransferType
Uses FileChannel.transferTo(long, long, java.nio.channels.WritableByteChannel) to transfer data over the network.
transferTo(ByteBuf) - Method in class alluxio.worker.block.io.BlockReader
Transfers data (up to buf.writableBytes()) from this reader to the buffer.
transferTo(ByteBuf) - Method in class alluxio.worker.block.io.DelegatingBlockReader
 
transferTo(ByteBuf) - Method in class alluxio.worker.block.io.LocalFileBlockReader
 
TRANSFORM_JOB_DOES_NOT_EXIST - alluxio.exception.ExceptionMessage
 
TRANSFORM_JOB_ID_NOT_FOUND_IN_JOB_SERVICE - alluxio.exception.ExceptionMessage
 
TRANSFORM_TABLE_URI_LACKS_AUTHORITY - alluxio.exception.ExceptionMessage
 
TRANSFORM_TABLE_URI_LACKS_SCHEME - alluxio.exception.ExceptionMessage
 
translateModeToPosixPermissions(int) - Static method in class alluxio.util.io.FileUtils
Translate mode to posix file permissions.
translatePosixPermissionToMode(Set<PosixFilePermission>) - Static method in class alluxio.util.io.FileUtils
Translate posix file permissions to short mode.
TrieNode<V> - Class in alluxio.conf.path
A node in a trie.
TrieNode() - Constructor for class alluxio.conf.path.TrieNode
 
truncateMessageLineLength(Object) - Static method in class alluxio.util.LogUtils
Truncates each line of a message to a certain length.
truncateMessageLineLength(Object, int) - Static method in class alluxio.util.LogUtils
Truncates each line of a message to a certain length.
TRUSTED - alluxio.master.file.meta.xattr.ExtendedAttribute.NamespacePrefix
 
TRY_CACHE - alluxio.client.WriteType
Deprecated.
This write type is deprecated as of v0.8 and not recommended for use. Use either WriteType.MUST_CACHE or WriteType.CACHE_THROUGH depending on your data persistence requirements.
tryComplete() - Method in class alluxio.concurrent.jsr.CountedCompleter
If the pending count is nonzero, decrements the count; otherwise invokes CountedCompleter.onCompletion(CountedCompleter) and then similarly tries to complete this task's completer, if one exists, else marks this task as complete.
tryGet(K, LockMode) - Method in class alluxio.collections.LockPool
Attempts to take a lock on the given key.
tryUnfork() - Method in class alluxio.concurrent.jsr.ForkJoinTask
Tries to unschedule this task for execution.
TwoKeyConcurrentMap<K1,​K2,​V,​M extends java.util.Map<K2,​V>> - Class in alluxio.collections
A two-level concurrent map implementation.
TwoKeyConcurrentMap(Supplier<M>) - Constructor for class alluxio.collections.TwoKeyConcurrentMap
 
TwoKeyConcurrentMap.TriFunction<A,​B,​C,​R> - Interface in alluxio.collections
A function with three arguments.
TwoKeyConcurrentSortedMap<K1,​K2,​V,​M extends java.util.SortedMap<K2,​V>> - Class in alluxio.collections
A two-level concurrent map implementation where the inner map is sorted.
TwoKeyConcurrentSortedMap(Supplier<M>) - Constructor for class alluxio.collections.TwoKeyConcurrentSortedMap
 
TYPE - alluxio.underfs.Fingerprint.Tag
 

U

UFS - alluxio.master.journal.JournalType
 
UFS - alluxio.underfs.Fingerprint.Tag
 
UFS_BLOCK_ACCESS_TOKEN_UNAVAILABLE - alluxio.exception.ExceptionMessage
 
UFS_CONFIG - Static variable in class alluxio.cli.ValidationConfig
 
UFS_INPUT_STREAM_CACHE_EXPIRATION - Static variable in class alluxio.Constants
 
UFS_JOURNAL_MOUNT_ID - Static variable in class alluxio.util.IdUtils
The journal ufs is stored as a special mount in the ufs manage.
UFS_OP_NOT_ALLOWED - alluxio.exception.ExceptionMessage
 
UFS_OP_PREFIX - Static variable in class alluxio.metrics.MetricInfo
 
UFS_OP_SAVED_PREFIX - Static variable in class alluxio.metrics.MetricInfo
 
UFS_PATH - Static variable in class alluxio.cli.ValidationConfig
 
UfsBlockAccessTokenUnavailableException - Exception in alluxio.exception
The exception thrown when it fails to grab a UFS access token for a UFS block.
UfsBlockAccessTokenUnavailableException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.UfsBlockAccessTokenUnavailableException
Constructs a new exception with the specified exception message and multiple parameters.
UfsBlockAccessTokenUnavailableException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.UfsBlockAccessTokenUnavailableException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
UfsBlockAccessTokenUnavailableException(String) - Constructor for exception alluxio.exception.UfsBlockAccessTokenUnavailableException
Constructs a new exception with the specified detail message.
UfsBlockAccessTokenUnavailableException(String, Throwable) - Constructor for exception alluxio.exception.UfsBlockAccessTokenUnavailableException
Constructs a new exception with the specified detail message and cause.
UfsCallable() - Constructor for class alluxio.underfs.UnderFileSystemWithLogging.UfsCallable
 
UfsClient(Supplier<UnderFileSystem>, AlluxioURI) - Constructor for class alluxio.underfs.UfsManager.UfsClient
 
UfsDirectoryStatus - Class in alluxio.underfs
Information about a directory in the under file system.
UfsDirectoryStatus(UfsDirectoryStatus) - Constructor for class alluxio.underfs.UfsDirectoryStatus
Creates a new instance of under directory information as a copy.
UfsDirectoryStatus(String, String, String, short) - Constructor for class alluxio.underfs.UfsDirectoryStatus
Creates new instance of UfsDirectoryStatus without providing last modified time or extended attributes.
UfsDirectoryStatus(String, String, String, short, Long) - Constructor for class alluxio.underfs.UfsDirectoryStatus
Creates new instance of UfsDirectoryStatus.
UfsDirectoryStatus(String, String, String, short, Long, Map<String, byte[]>) - Constructor for class alluxio.underfs.UfsDirectoryStatus
Creates new instance of UfsDirectoryStatus.
UfsFileStatus - Class in alluxio.underfs
Information about a file in UnderFileSystem.
UfsFileStatus(UfsFileStatus) - Constructor for class alluxio.underfs.UfsFileStatus
Creates a new instance of UfsFileStatus as a copy.
UfsFileStatus(String, String, long, Long, String, String, short) - Constructor for class alluxio.underfs.UfsFileStatus
Deprecated.
as of 2.1.0, use #UfsFileStatus(String, String, long, long, String, String, short, long).
UfsFileStatus(String, String, long, Long, String, String, short, long) - Constructor for class alluxio.underfs.UfsFileStatus
Creates new instance of UfsFileStatus without any extended attributes.
UfsFileStatus(String, String, long, Long, String, String, short, Map<String, byte[]>) - Constructor for class alluxio.underfs.UfsFileStatus
Deprecated.
as of 2.1.0, use #UfsFileStatus(String, String, long, long, String, String, short, Map, long)
UfsFileStatus(String, String, long, Long, String, String, short, Map<String, byte[]>, long) - Constructor for class alluxio.underfs.UfsFileStatus
Creates new instance of UfsFileStatus.
UfsInfo - Class in alluxio.wire
Class to represent a ufs info.
UfsInfo() - Constructor for class alluxio.wire.UfsInfo
Creates a new instance of UfsInfo.
UfsManager - Interface in alluxio.underfs
A class that manages the UFS used by different services.
UfsManager.UfsClient - Class in alluxio.underfs
Container for a UFS and the URI for that UFS.
UfsMode - Enum in alluxio.underfs
Operation mode for under storage.
UfsStatus - Class in alluxio.underfs
Information about a file or a directory in the under file system.
UfsStatus(UfsStatus) - Constructor for class alluxio.underfs.UfsStatus
Creates a new instance of UfsStatus as a copy.
UfsStatus(String, boolean, String, String, short, Long, Map<String, byte[]>) - Constructor for class alluxio.underfs.UfsStatus
Creates new instance of UfsStatus.
UIFileBlockInfo - Class in alluxio.util.webui
Contains information for displaying a file block in the UI.
UIFileBlockInfo(long, long, long, String, AlluxioConfiguration) - Constructor for class alluxio.util.webui.UIFileBlockInfo
Creates a new instance of UIFileBlockInfo.
UIFileBlockInfo(FileBlockInfo, AlluxioConfiguration) - Constructor for class alluxio.util.webui.UIFileBlockInfo
Creates a new instance of UIFileBlockInfo.
UIFileInfo - Class in alluxio.util.webui
Contains information about a file to be displayed in the UI.
UIFileInfo(URIStatus, AlluxioConfiguration, List<String>) - Constructor for class alluxio.util.webui.UIFileInfo
Creates a new instance of UIFileInfo.
UIFileInfo(UIFileInfo.LocalFileInfo, AlluxioConfiguration, List<String>) - Constructor for class alluxio.util.webui.UIFileInfo
Creates a new instance of UIFileInfo.
UIFileInfo(FileInfo, AlluxioConfiguration, List<String>) - Constructor for class alluxio.util.webui.UIFileInfo
Creates a new instance of UIFileInfo.
UIFileInfo.LocalFileInfo - Class in alluxio.util.webui
The type Local file info.
UIMasterInfo - Class in alluxio.util.webui
Displays information about a master in the UI.
UIMasterInfo(String, long, long) - Constructor for class alluxio.util.webui.UIMasterInfo
Creates a new instance of UIMasterInfo.
UIMountPointInfo - Class in alluxio.util.webui
Contains information about a mount point to be displayed in the UI.
UIMountPointInfo(String, MountPointInfo) - Constructor for class alluxio.util.webui.UIMountPointInfo
Instantiates a new instance of UIMountPointInfo.
UIStorageDir - Class in alluxio.util.webui
Displays information about a storage directory in the UI.
UIStorageDir(String, String, long, long) - Constructor for class alluxio.util.webui.UIStorageDir
Creates a new instance of UIStorageDir.
UIUsageOnTier - Class in alluxio.util.webui
A wrapper class of the usage info per tier for displaying in the UI.
UIUsageOnTier(String, long, long) - Constructor for class alluxio.util.webui.UIUsageOnTier
Creates a new instance of UIUsageOnTier.
UIWorkerInfo - Class in alluxio.util.webui
Displays information about a worker in the UI.
UIWorkerInfo(String, long, String) - Constructor for class alluxio.util.webui.UIWorkerInfo
Creates a new instance of UIWorkerInfo.
UNABLE_TO_DETERMINE_MASTER_HOSTNAME - alluxio.exception.ExceptionMessage
 
UnauthenticatedException - Exception in alluxio.exception.status
Exception indicating that the request does not have valid authentication credentials for the operation.
UnauthenticatedException(String) - Constructor for exception alluxio.exception.status.UnauthenticatedException
 
UnauthenticatedException(String, Throwable) - Constructor for exception alluxio.exception.status.UnauthenticatedException
 
UnauthenticatedException(Throwable) - Constructor for exception alluxio.exception.status.UnauthenticatedException
 
UnauthenticatedRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that the request does not have valid authentication credentials for the operation.
UnauthenticatedRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.UnauthenticatedRuntimeException
Constructor.
UnavailableException - Exception in alluxio.exception.status
Exception indicating that the service is currently unavailable.
UnavailableException(String) - Constructor for exception alluxio.exception.status.UnavailableException
 
UnavailableException(String, Throwable) - Constructor for exception alluxio.exception.status.UnavailableException
 
UnavailableException(Throwable) - Constructor for exception alluxio.exception.status.UnavailableException
 
UnavailableRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that the service is currently unavailable.
UnavailableRuntimeException(String) - Constructor for exception alluxio.exception.runtime.UnavailableRuntimeException
Constructor.
UnavailableRuntimeException(String, Throwable) - Constructor for exception alluxio.exception.runtime.UnavailableRuntimeException
Constructor.
UNDEFINED_CONFIGURATION_KEY - alluxio.exception.ExceptionMessage
 
UnderFileSystem - Interface in alluxio.underfs
Alluxio stores data into an under layer file system.
UnderFileSystem.Factory - Class in alluxio.underfs
The factory for the UnderFileSystem.
UnderFileSystem.SpaceType - Enum in alluxio.underfs
The different types of space indicate the total space, the free space and the space used in the under file system.
UnderFileSystemConfiguration - Class in alluxio.underfs
Ufs configuration properties, including ufs specific configuration and global configuration.
UnderFileSystemConfiguration(AlluxioConfiguration, boolean) - Constructor for class alluxio.underfs.UnderFileSystemConfiguration
Constructs a new instance of UnderFileSystemConfiguration with the given properties.
UnderFileSystemFactory - Interface in alluxio.underfs
Interface for under file system factories.
UnderFileSystemFactoryRegistry - Class in alluxio.underfs
Central registry of available UnderFileSystemFactory instances that uses the ServiceLoader mechanism to automatically discover available factories and provides a central place for obtaining actual UnderFileSystem instances.
UnderFileSystemUtils - Class in alluxio.util
Utility functions for working with UnderFileSystem.
UnderFileSystemWithLogging - Class in alluxio.underfs
This class forwards all calls to the UnderFileSystem interface to an internal implementation.
UnderFileSystemWithLogging.UfsCallable<T> - Class in alluxio.underfs
Interface representing a callable to the under storage system which throws an IOException if an error occurs during the external communication.
UNDERFS_ABFS_ACCOUNT_KEY - alluxio.conf.PropertyKey.Template
 
UNDERFS_ALLOW_SET_OWNER_FAILURE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_ALLOW_SET_OWNER_FAILURE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_AZURE_ACCOUNT_KEY - alluxio.conf.PropertyKey.Template
 
UNDERFS_AZURE_CLIENT_ID - alluxio.conf.PropertyKey.Template
 
UNDERFS_AZURE_CLIENT_SECRET - alluxio.conf.PropertyKey.Template
 
UNDERFS_AZURE_REFRESH_URL - alluxio.conf.PropertyKey.Template
 
UNDERFS_CEPHFS_AUTH_ID - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_AUTH_ID - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_AUTH_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_AUTH_KEY - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_AUTH_KEYFILE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_AUTH_KEYFILE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_AUTH_KEYRING - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_AUTH_KEYRING - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_CONF_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_CONF_FILE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_CONF_OPTS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_CONF_OPTS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_LOCALIZE_READS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_LOCALIZE_READS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_MDS_NAMESPACE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_MDS_NAMESPACE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_MON_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_MON_HOST - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_MOUNT_GID - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_MOUNT_GID - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_MOUNT_POINT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_MOUNT_POINT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CEPHFS_MOUNT_UID - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CEPHFS_MOUNT_UID - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CLEANUP_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CLEANUP_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_CLEANUP_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_CLEANUP_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_MAX_NUM - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_MAX_NUM - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_EVENTUAL_CONSISTENCY_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_DEFAULT_MODE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_DEFAULT_MODE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_DIRECTORY_SUFFIX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_DIRECTORY_SUFFIX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_RETRY_DELAY_MULTIPLIER - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_RETRY_DELAY_MULTIPLIER - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_RETRY_INITIAL_DELAY_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_RETRY_INITIAL_DELAY_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_RETRY_JITTER - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_RETRY_JITTER - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_RETRY_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_RETRY_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_RETRY_MAX_DELAY_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_RETRY_MAX_DELAY_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_RETRY_TOTAL_DURATION_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_RETRY_TOTAL_DURATION_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_GCS_VERSION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_GCS_VERSION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_HDFS_CONFIGURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_HDFS_CONFIGURATION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_HDFS_IMPL - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_HDFS_IMPL - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_HDFS_PREFIXES - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_HDFS_PREFIXES - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_HDFS_REMOTE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_HDFS_REMOTE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_IO_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_IO_THREADS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_KODO_CONNECT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_KODO_CONNECT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_KODO_REQUESTS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_KODO_REQUESTS_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_LISTING_LENGTH - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_LISTING_LENGTH - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_LOCAL_SKIP_BROKEN_SYMLINKS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_LOCAL_SKIP_BROKEN_SYMLINKS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_BREADCRUMBS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_BREADCRUMBS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_MOUNT_SHARED_PUBLICLY - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_MOUNT_SHARED_PUBLICLY - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_MULTI_RANGE_CHUNK_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_MULTI_RANGE_CHUNK_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_SERVICE_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_SERVICE_THREADS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_SKIP_PARENT_DIRECTORY_CREATION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_SKIP_PARENT_DIRECTORY_CREATION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBJECT_STORE_STREAMING_UPLOAD_PART_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBJECT_STORE_STREAMING_UPLOAD_PART_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBS_INTERMEDIATE_UPLOAD_CLEAN_AGE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBS_INTERMEDIATE_UPLOAD_CLEAN_AGE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBS_STREAMING_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBS_STREAMING_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBS_STREAMING_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBS_STREAMING_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OBS_STREAMING_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OBS_STREAMING_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_CONNECT_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_CONNECT_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_CONNECT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_CONNECT_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_CONNECT_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_CONNECT_TTL - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_ECS_RAM_ROLE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_ECS_RAM_ROLE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_INTERMEDIATE_UPLOAD_CLEAN_AGE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_INTERMEDIATE_UPLOAD_CLEAN_AGE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_RETRY_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_RETRY_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_STREAMING_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_STREAMING_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_STREAMING_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_STREAMING_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_STREAMING_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_STREAMING_UPLOAD_THREADS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_STS_ECS_METADATA_SERVICE_ENDPOINT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_STS_ECS_METADATA_SERVICE_ENDPOINT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_STS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_STS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OSS_STS_TOKEN_REFRESH_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OSS_STS_TOKEN_REFRESH_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_OZONE_PREFIXES - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_OZONE_PREFIXES - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_PERSISTENCE_ASYNC_TEMP_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_PERSISTENCE_ASYNC_TEMP_DIR - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_ADMIN_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_ADMIN_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_BULK_DELETE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_BULK_DELETE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_CONNECT_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_CONNECT_TTL - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_DEFAULT_MODE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_DEFAULT_MODE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_DIRECTORY_SUFFIX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_DIRECTORY_SUFFIX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_DISABLE_DNS_BUCKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_DISABLE_DNS_BUCKETS - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_ENDPOINT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_ENDPOINT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_ENDPOINT_REGION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_ENDPOINT_REGION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_INHERIT_ACL - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_INHERIT_ACL - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_INTERMEDIATE_UPLOAD_CLEAN_AGE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_INTERMEDIATE_UPLOAD_CLEAN_AGE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_LIST_OBJECTS_V1 - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_LIST_OBJECTS_V1 - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_MAX_ERROR_RETRY - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_MAX_ERROR_RETRY - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_OWNER_ID_TO_USERNAME_MAPPING - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_PROXY_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_PROXY_HOST - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_PROXY_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_PROXY_PORT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_REGION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_REGION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_REQUEST_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_REQUEST_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_SECURE_HTTP_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_SECURE_HTTP_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_SERVER_SIDE_ENCRYPTION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_SERVER_SIDE_ENCRYPTION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_SIGNER_ALGORITHM - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_SIGNER_ALGORITHM - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_SOCKET_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_STREAMING_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_STREAMING_UPLOAD_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_STREAMING_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_STREAMING_UPLOAD_PARTITION_SIZE - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_S3_UPLOAD_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_S3_UPLOAD_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_STRICT_VERSION_MATCH_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_STRICT_VERSION_MATCH_ENABLED - Static variable in class alluxio.conf.PropertyKey
UFS related properties.
UNDERFS_VERSION - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_VERSION - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_WEB_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_WEB_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_WEB_HEADER_LAST_MODIFIED - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_WEB_HEADER_LAST_MODIFIED - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_WEB_PARENT_NAMES - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_WEB_PARENT_NAMES - Static variable in class alluxio.conf.PropertyKey
 
UNDERFS_WEB_TITLES - Static variable in class alluxio.conf.PropertyKey.Name
 
UNDERFS_WEB_TITLES - Static variable in class alluxio.conf.PropertyKey
 
UNDERSCORE - Static variable in class alluxio.underfs.Fingerprint
 
UnderStorageType - Enum in alluxio.client
Specifies the type of data interaction with Alluxio's Under Storage.
unescape(String) - Static method in class alluxio.metrics.MetricsSystem
Unescapes a URI, reverts it to before the escape, to display it correctly.
UnexpectedAlluxioException - Exception in alluxio.exception
The exception thrown when an unexpected error occurs within the Alluxio system.
UnexpectedAlluxioException(String) - Constructor for exception alluxio.exception.UnexpectedAlluxioException
Constructs a new exception with the specified detail message.
uniformTimer(String) - Static method in class alluxio.metrics.MetricsSystem
Same with MetricsSystem.timer(java.lang.String) but with UnirformReservoir for sampling.
UnimplementedException - Exception in alluxio.exception.status
Exception indicating that an operation is not implemented or not supported/enabled in this service.
UnimplementedException(String) - Constructor for exception alluxio.exception.status.UnimplementedException
 
UnimplementedException(String, Throwable) - Constructor for exception alluxio.exception.status.UnimplementedException
 
UnimplementedException(Throwable) - Constructor for exception alluxio.exception.status.UnimplementedException
 
UnimplementedRuntimeException - Exception in alluxio.exception.runtime
Exception indicating that an operation is not implemented or not supported/enabled in this service.
UnimplementedRuntimeException(String) - Constructor for exception alluxio.exception.runtime.UnimplementedRuntimeException
Constructor.
UnimplementedRuntimeException(Throwable, ErrorType) - Constructor for exception alluxio.exception.runtime.UnimplementedRuntimeException
Constructor.
uniqPath() - Static method in class alluxio.util.io.PathUtils
Creates a unique path based off the caller.
UniqueBlockingQueue<T> - Class in alluxio.util.executor
A blocking queue containing only unique elements, based on LinkedBlockingQueue implementation.
UniqueBlockingQueue(int) - Constructor for class alluxio.util.executor.UniqueBlockingQueue
Constructor for a UniqueBlockingQueue.
UniqueFieldIndex<T,​V> - Class in alluxio.collections
A class representing a unique index.
UniqueFieldIndex(IndexDefinition<T, V>) - Constructor for class alluxio.collections.UniqueFieldIndex
Constructs a new UniqueFieldIndex instance.
UnixMountInfo - Class in alluxio.util
Class representing an entry in a Unix /etc/fstab file.
UnixMountInfo.Builder - Class in alluxio.util
Builder for UnixMountInfo.
UnixMountInfo.Options - Class in alluxio.util
Unix mount info options.
UnixMountInfo.Options.Builder - Class in alluxio.util
Builder for Unix mount info options.
UNKNOWN - alluxio.conf.Source.Type
The unknown source which has the lowest priority.
UNKNOWN - alluxio.wire.CommandType
Unknown command.
UNKNOWN - Static variable in class alluxio.conf.Source
 
UNKNOWN_BLOCK_SIZE - Static variable in class alluxio.underfs.UfsFileStatus
 
UNKNOWN_ENUM - alluxio.exception.ExceptionMessage
 
UNKNOWN_PROPERTY - alluxio.exception.ExceptionMessage
 
UNKNOWN_SERVICE_VERSION - Static variable in class alluxio.Constants
 
UNKNOWN_SIZE - Static variable in class alluxio.Constants
 
UNKNOWN_VERSION - Static variable in class alluxio.extensions.ExtensionFactoryRegistry
 
UnknownAuthority - Class in alluxio.uri
An unknown authority implementation.
UnknownAuthority(String) - Constructor for class alluxio.uri.UnknownAuthority
 
UnknownException - Exception in alluxio.exception.status
Exception representing an unknown error.
UnknownException(String) - Constructor for exception alluxio.exception.status.UnknownException
 
UnknownException(String, Throwable) - Constructor for exception alluxio.exception.status.UnknownException
 
UnknownException(Throwable) - Constructor for exception alluxio.exception.status.UnknownException
 
UnknownRuntimeException - Exception in alluxio.exception.runtime
Exception representing an unknown error.
UnknownRuntimeException(String) - Constructor for exception alluxio.exception.runtime.UnknownRuntimeException
Constructor.
UnknownRuntimeException(Throwable) - Constructor for exception alluxio.exception.runtime.UnknownRuntimeException
Constructor.
UNLIMITED - Static variable in class alluxio.client.quota.CacheQuota
A predefined CacheQuota instance that sets NO limit.
unlockBlock(long) - Method in interface alluxio.worker.block.BlockStore
Releases an acquired block lock based on a lockId (returned by BlockStore.lockBlock(long, long).
unlockBlock(long) - Method in interface alluxio.worker.block.BlockWorker
Releases the lock with the specified lock id.
unlockBlock(long, long) - Method in interface alluxio.worker.block.BlockStore
Releases an acquired block lock based on a session id and block id.
unlockBlock(long, long) - Method in interface alluxio.worker.block.BlockWorker
Releases the lock with the specified session and block id.
UnmodifiableArrayList<T> - Class in alluxio.collections
This class provides an unmodifiable List proxy for an underlying array.
UnmodifiableArrayList(T[]) - Constructor for class alluxio.collections.UnmodifiableArrayList
 
unpinBlock(BlockLock) - Method in interface alluxio.worker.block.BlockStore
Unpins an accessed block based on the id (returned by BlockStore.pinBlock(long, long)).
unregister(PropertyKey) - Static method in class alluxio.conf.PropertyKey
Unregisters the given key from the global key map.
unregister(Reconfigurable) - Static method in class alluxio.conf.ReconfigurableRegistry
remove the listener related to the given property.
unregister(MetricKey) - Static method in class alluxio.metrics.MetricKey
Unregisters the given key from the global key map.
unregister(UnderFileSystemFactory) - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Unregisters an existing factory.
unregister(T) - Method in class alluxio.extensions.ExtensionFactoryRegistry
Unregisters an existing factory.
unregisterChannel(UUID) - Method in interface alluxio.security.authentication.AuthenticationServer
Unregisters given channel.
unregisterChannel(UUID) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
unset(PropertyKey) - Static method in class alluxio.conf.Configuration
Unsets the value for the appropriate key in the Properties.
unset(PropertyKey) - Method in class alluxio.conf.InstancedConfiguration
Unsets the value for the appropriate key in the Properties.
unwrap(byte[], int, int) - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
unwrapResponse(Protocol.Response) - Static method in class alluxio.util.CommonUtils
Unwraps a Protocol.Response.
unwrapResponseFrom(Protocol.Response, Channel) - Static method in class alluxio.util.CommonUtils
Unwraps a Protocol.Response associated with a channel.
update() - Method in interface alluxio.conf.Reconfigurable
When the property changed, this function will be invoked.
update() - Static method in class alluxio.conf.ReconfigurableRegistry
When the property was reconfigured, this function will be invoked.
update(long) - Method in class alluxio.metrics.MaxReservoir
Adds a new recorded value to the reservoir.
UPDATE_CHECK_ENABLED - Static variable in class alluxio.ProjectConstants
 
UPDATE_CHECK_HOST - Static variable in class alluxio.ProjectConstants
 
UPDATE_CHECK_MAGIC_NUMBER - Static variable in class alluxio.ProjectConstants
 
updateByModeBits(Mode.Bits) - Method in class alluxio.security.authorization.AclActions
Updates permitted actions based on the mode bits.
UpdateCheck - Class in alluxio.check
Check for updates.
updateIntervalMs(long) - Method in class alluxio.heartbeat.HeartbeatThread
Updates the heartbeat interval.
updateLastUpdatedTimeMs() - Method in class alluxio.wire.MasterInfo
Updates the last updated time of the master (in milliseconds).
updateMask() - Method in class alluxio.security.authorization.AccessControlList
Update the mask to be the union of owning group entry, named user entry and named group entry.
updateMask(AclActions) - Method in class alluxio.security.authorization.ExtendedACLEntries
Update the mask to be the union of owning group entry, named user entry and named group entry.
updatePinList(Set<Long>) - Method in interface alluxio.worker.block.BlockWorker
Sets the pinlist for the underlying block store.
updatePinnedInodes(Set<Long>) - Method in interface alluxio.worker.block.BlockStore
Update the pinned inodes.
updateValues(Set<Metric>) - Method in class alluxio.metrics.aggregator.SingleTagValueAggregator
 
updateValues(Set<Metric>) - Method in interface alluxio.metrics.MultiValueMetricsAggregator
Updates the aggregated values from the filtered metrics.
UPLOAD_THRESHOLD - Static variable in class alluxio.underfs.ObjectLowLevelOutputStream
Only parts bigger than 5MB could be uploaded through multipart upload, except the last part.
uploadPart() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
Uploads part async.
uploadPart(File, int, boolean) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
uploadPartInternal(File, int, boolean, String) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
URI - Interface in alluxio.uri
This interface represents a URI.
URI.Factory - Class in alluxio.uri
Factory for URI.
URIStatus - Class in alluxio.client.file
Wrapper around FileInfo.
URIStatus(FileInfo) - Constructor for class alluxio.client.file.URIStatus
Constructs an instance of this class from a FileInfo.
URIStatus(FileInfo, CacheContext) - Constructor for class alluxio.client.file.URIStatus
Constructs an instance of this class from a FileInfo.
URIUtils - Class in alluxio.util
Utility methods for working with URIs.
USED_BYTES - alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 
USED_BYTES_ON_TIERS - alluxio.wire.BlockMasterInfo.BlockMasterInfoField
 
useDisplayValue(boolean) - Method in class alluxio.conf.ConfigurationValueOptions
 
User - Class in alluxio.security
This class represents a user in Alluxio.
User(String) - Constructor for class alluxio.security.User
Constructs a new user with a name.
USER - alluxio.master.file.meta.xattr.ExtendedAttribute.NamespacePrefix
 
USER_AGENT_SEPARATOR - Static variable in class alluxio.check.UpdateCheck
 
USER_APP_ID - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_APP_ID - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_AVOID_EVICTION_POLICY_RESERVED_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_AVOID_EVICTION_POLICY_RESERVED_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_READ_METRICS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_READ_METRICS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_READ_RETRY_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_READ_RETRY_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_READ_RETRY_SLEEP_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_READ_RETRY_SLEEP_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_READ_RETRY_SLEEP_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_READ_RETRY_SLEEP_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_REMOTE_READ_BUFFER_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_REMOTE_READ_BUFFER_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_SIZE_BYTES_DEFAULT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_SIZE_BYTES_DEFAULT - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_POOL_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_POOL_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_WORKER_CLIENT_POOL_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WORKER_CLIENT_POOL_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_BLOCK_WRITE_LOCATION_POLICY - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_BLOCK_WRITE_LOCATION_POLICY - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_ASYNC_RESTORE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_ASYNC_RESTORE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_ASYNC_WRITE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_ASYNC_WRITE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_ASYNC_WRITE_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_ASYNC_WRITE_THREADS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_DIRS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_DIRS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_EVICTION_RETRIES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_EVICTION_RETRIES - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_EVICTOR_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_EVICTOR_CLASS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_EVICTOR_LFU_LOGBASE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_EVICTOR_LFU_LOGBASE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_EVICTOR_NONDETERMINISTIC_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_EVICTOR_NONDETERMINISTIC_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_FILTER_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_FILTER_CLASS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_FILTER_CONFIG_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_FILTER_CONFIG_FILE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_IN_STREAM_BUFFER_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_IN_STREAM_BUFFER_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_LOCAL_STORE_FILE_BUCKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_LOCAL_STORE_FILE_BUCKETS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_PAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_PAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_QUOTA_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_QUOTA_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_BLOOMFILTER_NUM - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_BLOOMFILTER_NUM - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_CLOCK_BITS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_CLOCK_BITS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SCOPE_BITS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SCOPE_BITS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_BITS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_BITS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_ENCODER_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_ENCODER_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_PREFIX_BITS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_PREFIX_BITS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_SUFFIX_BITS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_CUCKOO_SIZE_SUFFIX_BITS - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_MEMORY_OVERHEAD - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_MEMORY_OVERHEAD - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_TYPE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SHADOW_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SHADOW_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_STORE_OVERHEAD - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_STORE_OVERHEAD - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_STORE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_STORE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_TIMEOUT_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_TIMEOUT_DURATION - Static variable in class alluxio.conf.PropertyKey
 
USER_CLIENT_CACHE_TIMEOUT_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CLIENT_CACHE_TIMEOUT_THREADS - Static variable in class alluxio.conf.PropertyKey
 
USER_COMPONENT - Static variable in enum alluxio.security.authorization.AclEntryType
 
USER_CONF_CLUSTER_DEFAULT_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CONF_CLUSTER_DEFAULT_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_CONF_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_CONF_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
USER_DATE_FORMAT_PATTERN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_DATE_FORMAT_PATTERN - Static variable in class alluxio.conf.PropertyKey
 
USER_DIRECT_MEMORY_IO_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_BUFFER_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_BUFFER_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_COPYFROMLOCAL_BLOCK_LOCATION_POLICY - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_COPYFROMLOCAL_BLOCK_LOCATION_POLICY - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_CREATE_TTL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_CREATE_TTL - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_CREATE_TTL_ACTION - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_CREATE_TTL_ACTION - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_DELETE_UNCHECKED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_DELETE_UNCHECKED - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_INCLUDE_OPERATION_ID - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_INCLUDE_OPERATION_ID - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_GC_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_MASTER_CLIENT_POOL_SIZE_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_METADATA_LOAD_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_METADATA_LOAD_TYPE - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_METADATA_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_METADATA_SYNC_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_PASSIVE_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_PASSIVE_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_PERSIST_ON_RENAME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_PERSIST_ON_RENAME - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_PERSISTENCE_INITIAL_WAIT_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_PERSISTENCE_INITIAL_WAIT_TIME - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_READ_TYPE_DEFAULT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_READ_TYPE_DEFAULT - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_REPLICATION_DURABLE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_REPLICATION_DURABLE - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_REPLICATION_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_REPLICATION_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_REPLICATION_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_REPLICATION_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_RESERVED_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_RESERVED_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_SEQUENTIAL_PREAD_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_SEQUENTIAL_PREAD_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_TARGET_MEDIA - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_TARGET_MEDIA - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_UFS_TIER_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_UFS_TIER_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WAITCOMPLETED_POLL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WAITCOMPLETED_POLL_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WRITE_INIT_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WRITE_INIT_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WRITE_INIT_SLEEP_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WRITE_INIT_SLEEP_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WRITE_INIT_SLEEP_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WRITE_INIT_SLEEP_MIN - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WRITE_TIER_DEFAULT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WRITE_TIER_DEFAULT - Static variable in class alluxio.conf.PropertyKey
 
USER_FILE_WRITE_TYPE_DEFAULT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_FILE_WRITE_TYPE_DEFAULT - Static variable in class alluxio.conf.PropertyKey
 
USER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
USER_LOCAL_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_LOCAL_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_LOCAL_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_LOCAL_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_LOGGING_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
USER_LOGS_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_LOGS_DIR - Static variable in class alluxio.conf.PropertyKey
 
USER_MASTER_POLLING_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_MASTER_POLLING_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_METADATA_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_METADATA_CACHE_EXPIRATION_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_METADATA_CACHE_EXPIRATION_TIME - Static variable in class alluxio.conf.PropertyKey
 
USER_METADATA_CACHE_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_METADATA_CACHE_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_METRICS_COLLECTION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_METRICS_COLLECTION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_METRICS_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_METRICS_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETTY_DATA_TRANSMISSION_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETTY_DATA_TRANSMISSION_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_DATA_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_DATA_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_FLOWCONTROL_WINDOW - alluxio.conf.PropertyKey.Template
 
USER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_KEEPALIVE_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_KEEPALIVE_TIME - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_KEEPALIVE_TIME_MS - alluxio.conf.PropertyKey.Template
 
USER_NETWORK_KEEPALIVE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_KEEPALIVE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_KEEPALIVE_TIMEOUT_MS - alluxio.conf.PropertyKey.Template
 
USER_NETWORK_MAX_CONNECTIONS - alluxio.conf.PropertyKey.Template
 
USER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - alluxio.conf.PropertyKey.Template
 
USER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_NETTY_CHANNEL - alluxio.conf.PropertyKey.Template
 
USER_NETWORK_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_NETTY_CHANNEL_POOL_DISABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL_POOL_DISABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_CHANNEL_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL_POOL_GC_THRESHOLD_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_CHANNEL_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_CHANNEL_POOL_SIZE_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_READER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_READER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_WORKER_THREADS - alluxio.conf.PropertyKey.Template
 
USER_NETWORK_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_NETTY_WRITER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_WRITER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_WRITER_CLOSE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_WRITER_CLOSE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_NETTY_WRITER_PACKET_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_NETTY_WRITER_PACKET_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_READER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_READER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_RPC_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_RPC_KEEPALIVE_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_KEEPALIVE_TIME - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_RPC_KEEPALIVE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_KEEPALIVE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_RPC_MAX_CONNECTIONS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_MAX_CONNECTIONS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_RPC_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_RPC_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_RPC_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_RPC_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_KEEPALIVE_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_KEEPALIVE_TIME - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_KEEPALIVE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_KEEPALIVE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_MAX_CONNECTIONS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_MAX_CONNECTIONS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_STREAMING_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_STREAMING_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey
 
USER_NETWORK_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_WRITER_CLOSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_WRITER_CLOSE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_WRITER_FLUSH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_WRITER_FLUSH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
USER_NETWORK_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_NETWORK_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey
USER_POSITION_READER_STREAMING_MULTIPLIER - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_POSITION_READER_STREAMING_MULTIPLIER - Static variable in class alluxio.conf.PropertyKey
 
USER_RPC_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_RPC_RETRY_BASE_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_RPC_RETRY_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_RPC_RETRY_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey
 
USER_RPC_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_RPC_RETRY_MAX_SLEEP_MS - Static variable in class alluxio.conf.PropertyKey
 
USER_RPC_SHUFFLE_MASTERS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_RPC_SHUFFLE_MASTERS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_SHORT_CIRCUIT_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_SHORT_CIRCUIT_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_SHORT_CIRCUIT_PREFERRED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_SHORT_CIRCUIT_PREFERRED - Static variable in class alluxio.conf.PropertyKey
 
USER_SKIP_AUTHORITY_CHECK - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_SKIP_AUTHORITY_CHECK - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_DATA_READ_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_DATA_READ_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_DATA_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_DATA_WRITE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_DATA_WRITE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_READER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_READER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_READER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_READER_CLOSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_READER_CLOSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_WRITER_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_WRITER_CLOSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_WRITER_CLOSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_WRITER_FLUSH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_WRITER_FLUSH_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
USER_STREAMING_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_STREAMING_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_UFS_BLOCK_LOCATION_ALL_FALLBACK_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UFS_BLOCK_LOCATION_ALL_FALLBACK_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_UFS_BLOCK_READ_CONCURRENCY_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UFS_BLOCK_READ_CONCURRENCY_MAX - Static variable in class alluxio.conf.PropertyKey
 
USER_UFS_BLOCK_READ_LOCATION_POLICY - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UFS_BLOCK_READ_LOCATION_POLICY - Static variable in class alluxio.conf.PropertyKey
 
USER_UFS_BLOCK_READ_LOCATION_POLICY_CACHE_EXPIRATION_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UFS_BLOCK_READ_LOCATION_POLICY_CACHE_EXPIRATION_TIME - Static variable in class alluxio.conf.PropertyKey
 
USER_UFS_BLOCK_READ_LOCATION_POLICY_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UFS_BLOCK_READ_LOCATION_POLICY_CACHE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
USER_UFS_BLOCK_READ_LOCATION_POLICY_DETERMINISTIC_HASH_SHARDS - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UFS_BLOCK_READ_LOCATION_POLICY_DETERMINISTIC_HASH_SHARDS - Static variable in class alluxio.conf.PropertyKey
 
USER_UNSAFE_DIRECT_LOCAL_IO_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UPDATE_FILE_ACCESSTIME_DISABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_UPDATE_FILE_ACCESSTIME_DISABLED - Static variable in class alluxio.conf.PropertyKey
 
USER_WORKER_LIST_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
USER_WORKER_LIST_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
useRawValue(boolean) - Method in class alluxio.conf.ConfigurationValueOptions
 
userEventTriggered(ChannelHandlerContext, Object) - Method in class alluxio.network.netty.IdleWriteHandler
 
userKeySet() - Method in interface alluxio.conf.AlluxioConfiguration
 
userKeySet() - Method in class alluxio.conf.AlluxioProperties
 
userKeySet() - Method in class alluxio.conf.InstancedConfiguration
 
userKeySet() - Method in class alluxio.conf.path.SpecificPathConfiguration
 
userKeySet() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
UserState - Interface in alluxio.security.user
UserState handles logging in any client, and maintains the state.
UserState.Factory - Class in alluxio.security.user
A factory for creating a UserState.
UserStateFactory - Interface in alluxio.security.user
A factory for creating new UserState instances.

V

validate() - Method in interface alluxio.conf.AlluxioConfiguration
Validates the configuration.
validate() - Method in class alluxio.conf.InstancedConfiguration
 
validate() - Method in class alluxio.conf.path.SpecificPathConfiguration
 
validate() - Method in class alluxio.network.protocol.RPCMessage
Validates the message.
validate() - Method in class alluxio.network.protocol.RPCProtoMessage
 
validate() - Method in class alluxio.underfs.UnderFileSystemConfiguration
 
validate(Map<String, String>) - Method in class alluxio.cli.AbstractValidationTask
 
validate(Map<String, String>) - Method in interface alluxio.cli.ValidationTask
Runs the validation task.
validateArgs(CommandLine) - Method in interface alluxio.cli.Command
Checks if the arguments are valid or throw InvalidArgumentException.
validateImpl(Map<String, String>) - Method in class alluxio.cli.AbstractValidationTask
 
validatePath(String) - Static method in class alluxio.underfs.BaseUnderFileSystem
Clean the path by creating a URI and turning it back to a string.
validatePath(String) - Static method in class alluxio.util.io.PathUtils
Checks if the given path is properly formed.
validateValue(Object) - Method in class alluxio.conf.PropertyKey
 
ValidationConfig - Class in alluxio.cli
Configuration settings for the validation tools.
ValidationConfig() - Constructor for class alluxio.cli.ValidationConfig
 
ValidationResults - Class in alluxio.cli
A container class for the validation results.
ValidationResults() - Constructor for class alluxio.cli.ValidationResults
 
ValidationTask - Interface in alluxio.cli
Interface for a validation task run by validateEnv command.
ValidationTaskResult - Class in alluxio.cli
Represents the result of a given task.
ValidationTaskResult() - Constructor for class alluxio.cli.ValidationTaskResult
Creates a new ValidationTaskResult.
ValidationTaskResult(ValidationUtils.State, String, String, String) - Constructor for class alluxio.cli.ValidationTaskResult
Creates a new ValidationTaskResult.
ValidationTaskResult(ValidationUtils.State, String, String, String, String) - Constructor for class alluxio.cli.ValidationTaskResult
Creates a new ValidationTaskResult.
ValidationTool - Interface in alluxio.cli
The validation tool interface.
ValidationToolFactory - Interface in alluxio.cli
The validation tool factory interface.
ValidationToolRegistry - Class in alluxio.cli
The registry of validation tool implementations.
ValidationToolRegistry(AlluxioConfiguration) - Constructor for class alluxio.cli.ValidationToolRegistry
Creates a new instance of an ValidationToolRegistry.
ValidationUtils - Class in alluxio.cli
Utilities to run the validation tests.
ValidationUtils.State - Enum in alluxio.cli
Task State.
value() - Method in annotation type alluxio.annotation.SuppressFBWarnings
 
valueAsString(String) - Static method in class alluxio.util.ConfigurationUtils
 
valueOf(String) - Static method in enum alluxio.cli.ValidationUtils.State
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.AlluxioStorageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.file.cache.ShadowCacheType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.file.cache.store.PageStoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.file.CacheContext.StatsUnit
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.quota.CacheScope.Level
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.ReadType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.UnderStorageType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.client.WriteType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.concurrent.LockMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.conf.PropertyKey.ConsistencyCheckLevel
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.conf.PropertyKey.DisplayType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.conf.PropertyKey.PropertyType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.conf.PropertyKey.Template
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.conf.Source.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.exception.ExceptionMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.exception.PreconditionMessage
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.executor.RpcExecutorType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.executor.ThreadPoolExecutorQueueType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.file.options.DescendantType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.grpc.GrpcNetworkGroup
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.heartbeat.HeartbeatContext.HeartbeatType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.meta.PersistenceState
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.meta.xattr.ExtendedAttribute.NamespacePrefix
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.file.MetadataSyncTraversalOrder
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.GraceMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.journal.JournalType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.metastore.MetastoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.metastore.rocks.DataBlockIndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.metastore.rocks.IndexType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.master.ZookeeperConnectionErrorPolicy
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.metrics.MetricInfo.UfsOps
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.metrics.MetricsSystem.InstanceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.network.ChannelType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.network.netty.FileTransferType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.network.protocol.RPCMessage.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.security.authentication.AuthType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.security.authorization.AclAction
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.security.authorization.AclEntryType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.security.authorization.Mode.Bits
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.time.ExponentialTimer.Result
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.Fingerprint.Tag
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.Fingerprint.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.UfsMode
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.underfs.UnderFileSystem.SpaceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.util.CommonUtils.ProcessType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.CommandType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.LoadMetadataType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.wire.SyncPointInfo.SyncStatus
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.worker.block.BlockStoreType
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.worker.block.io.BlockClient.Type
Returns the enum constant of this type with the specified name.
valueOf(String) - Static method in enum alluxio.worker.block.management.BackoffStrategy
Returns the enum constant of this type with the specified name.
values() - Static method in enum alluxio.cli.ValidationUtils.State
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.AlluxioStorageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.file.cache.ShadowCacheType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.file.cache.store.PageStoreType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.file.CacheContext.StatsUnit
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.quota.CacheScope.Level
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.ReadType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.UnderStorageType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.client.WriteType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Method in class alluxio.collections.ConcurrentIdentityHashMap
 
values() - Static method in enum alluxio.concurrent.LockMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.conf.PropertyKey.ConsistencyCheckLevel
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.conf.PropertyKey.DisplayType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.conf.PropertyKey.PropertyType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.conf.PropertyKey.Template
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.conf.Source.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.exception.ExceptionMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.exception.PreconditionMessage
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.executor.RpcExecutorType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.executor.ThreadPoolExecutorQueueType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.file.options.DescendantType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.grpc.GrpcNetworkGroup
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.heartbeat.HeartbeatContext.HeartbeatType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.meta.PersistenceState
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.meta.xattr.ExtendedAttribute.NamespacePrefix
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.file.MetadataSyncTraversalOrder
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.GraceMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.journal.JournalType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.metastore.MetastoreType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.metastore.rocks.DataBlockIndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.metastore.rocks.IndexType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.master.ZookeeperConnectionErrorPolicy
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.metrics.MetricInfo.UfsOps
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.metrics.MetricsSystem.InstanceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.network.ChannelType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.network.netty.FileTransferType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.network.protocol.RPCMessage.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authentication.AuthType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authorization.AclAction
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authorization.AclEntryType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.security.authorization.Mode.Bits
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.time.ExponentialTimer.Result
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.Fingerprint.Tag
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.Fingerprint.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.UfsMode
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.underfs.UnderFileSystem.SpaceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.util.CommonUtils.ProcessType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.util.network.NetworkAddressUtils.ServiceType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.BlockMasterInfo.BlockMasterInfoField
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.CommandType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.LoadMetadataType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.wire.SyncPointInfo.SyncStatus
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.worker.block.BlockStoreType
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.worker.block.io.BlockClient.Type
Returns an array containing the constants of this enum type, in the order they are declared.
values() - Static method in enum alluxio.worker.block.management.BackoffStrategy
Returns an array containing the constants of this enum type, in the order they are declared.
VERSION - Static variable in class alluxio.conf.PropertyKey.Name
 
VERSION - Static variable in class alluxio.conf.PropertyKey
 
VERSION - Static variable in class alluxio.ProjectConstants
 
VERSION - Static variable in class alluxio.RuntimeConstants
The version of this Alluxio instance.
VERSION - Static variable in class alluxio.security.authentication.plain.PlainSaslServerProvider
 

W

waitFor(String, Supplier<Boolean>) - Static method in class alluxio.util.CommonUtils
Waits for a condition to be satisfied.
waitFor(String, Supplier<Boolean>, WaitForOptions) - Static method in class alluxio.util.CommonUtils
Waits for a condition to be satisfied.
waitForAllPartsUpload() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
WaitForOptions - Class in alluxio.util
waitForResult(String, Supplier<T>, Function<T, Boolean>) - Static method in class alluxio.util.CommonUtils
Waits for the object to meet a certain condition.
waitForResult(String, Supplier<T>, Function<T, Boolean>, WaitForOptions) - Static method in class alluxio.util.CommonUtils
Waits for the object to meet a certain condition.
warmUpLoop() - Static method in class alluxio.util.CommonUtils
Common empty loop utility that serves the purpose of warming up the JVM before performance microbenchmarks.
warn(String) - Method in class alluxio.util.logging.SamplingLogger
 
warn(String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
warn(String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
warn(String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
warn(String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String, Object) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String, Object...) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String, Object, Object) - Method in class alluxio.util.logging.SamplingLogger
 
warn(Marker, String, Throwable) - Method in class alluxio.util.logging.SamplingLogger
 
WARN - alluxio.conf.PropertyKey.ConsistencyCheckLevel
Check consistency of property value, show warning of inconsistent values.
WARN_TIME_EXCEEDED - Static variable in class alluxio.metrics.MetricKey.Name
 
WARN_TIME_EXCEEDED - Static variable in class alluxio.metrics.MetricKey
 
WARNING - alluxio.cli.ValidationUtils.State
 
warnWithException(Logger, String, Object...) - Static method in class alluxio.util.LogUtils
Log a warning message with full exception if debug logging is enabled, or just the exception string otherwise.
WEB_CORS_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_CORS_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WEB_FILE_INFO_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_FILE_INFO_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WEB_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_REFRESH_INTERVAL - Static variable in class alluxio.conf.PropertyKey
 
WEB_RESOURCES - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_RESOURCES - Static variable in class alluxio.conf.PropertyKey
 
WEB_THREAD_DUMP_TO_LOG - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_THREAD_DUMP_TO_LOG - Static variable in class alluxio.conf.PropertyKey
 
WEB_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_THREADS - Static variable in class alluxio.conf.PropertyKey
 
WEB_UI_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WEB_UI_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WebUtils - Class in alluxio.util.webui
The type Web utils.
whenComplete(BiConsumer<? super T, ? super Throwable>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
whenComplete(BiConsumer<? super T, ? super Throwable>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage with the same result or exception as this stage, that executes the given action when this stage completes.
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage with the same result or exception as this stage, that executes the given action using this stage's default asynchronous execution facility when this stage completes.
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>, Executor) - Method in class alluxio.concurrent.jsr.CompletableFuture
 
whenCompleteAsync(BiConsumer<? super T, ? super Throwable>, Executor) - Method in interface alluxio.concurrent.jsr.CompletionStage
Returns a new CompletionStage with the same result or exception as this stage, that executes the given action using the supplied Executor when this stage completes.
WILDCARD - Static variable in class alluxio.AlluxioURI
 
WILDCARD - Static variable in class alluxio.security.authentication.ImpersonationAuthenticator
 
WILDCARD_ADDRESS - Static variable in class alluxio.util.network.NetworkAddressUtils
 
WINDOWS - Static variable in class alluxio.util.network.NetworkAddressUtils
Checks if the underlying OS is Windows.
withChildOption(ChannelOption<T>, T) - Method in class alluxio.grpc.GrpcServerBuilder
Sets a netty channel option.
withCloseable(Closeable) - Method in class alluxio.grpc.GrpcService
Add a new closeable resource to this service's closer.
withInitialSleep(Duration) - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
withMaxDuration(Duration) - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
withMaxSleep(Duration) - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
withSkipInitialSleep() - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
first sleep will be skipped.
withTimeCtx(TimeContext) - Method in class alluxio.retry.ExponentialTimeBoundedRetry.Builder
 
withZone(ZoneId) - Method in class alluxio.clock.ElapsedTimeClock
 
withZone(ZoneId) - Method in class alluxio.clock.SystemClock
 
WORK_DIR - Static variable in class alluxio.conf.PropertyKey.Name
 
WORK_DIR - Static variable in class alluxio.conf.PropertyKey
 
Worker - Interface in alluxio.worker
Interface of an Alluxio worker.
WORKER - alluxio.metrics.MetricsSystem.InstanceType
 
WORKER - alluxio.util.CommonUtils.ProcessType
 
WORKER_ACTIVE_CLIENTS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_ACTIVE_RPC_READ_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_ACTIVE_RPC_WRITE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_ALLOCATOR_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_ALLOCATOR_CLASS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_ANNOTATOR_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BLOCK_ANNOTATOR_CLASS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_ANNOTATOR_LRFU_ATTENUATION_FACTOR - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BLOCK_ANNOTATOR_LRFU_ATTENUATION_FACTOR - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_ANNOTATOR_LRFU_STEP_FACTOR - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BLOCK_ANNOTATOR_LRFU_STEP_FACTOR - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BLOCK_HEARTBEAT_INTERVAL_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_HEARTBEAT_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BLOCK_HEARTBEAT_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_MASTER_CLIENT_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BLOCK_MASTER_CLIENT_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_READER_COMPLETED_TASK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_READER_THREAD_ACTIVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_READER_THREAD_CURRENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_READER_THREAD_MAX_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_REMOVER_REMOVED_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_REMOVER_REMOVING_BLOCKS_SIZE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_REMOVER_TRY_REMOVE_BLOCKS_SIZE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_REMOVER_TRY_REMOVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_SERIALIZED_COMPLETED_TASK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_SERIALIZED_THREAD_ACTIVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_SERIALIZED_THREAD_CURRENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_SERIALIZED_THREAD_MAX_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_STORE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_BLOCK_STORE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_BLOCK_SYNC - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
WORKER_BLOCK_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_BLOCK_WRITER_COMPLETED_TASK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_WRITER_THREAD_ACTIVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_WRITER_THREAD_CURRENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCK_WRITER_THREAD_MAX_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_ACCESSED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_CACHED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_CANCELLED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_DELETED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_EVICTED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_EVICTION_RATE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_LOST - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_PROMOTED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_READ_LOCAL - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_READ_REMOTE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BLOCKS_READ_UFS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_DIRECT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_DIRECT_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_DOMAIN - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_REMOTE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_REMOTE_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_UFS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_READ_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_DIRECT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_DIRECT_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_DOMAIN - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_DOMAIN_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_REMOTE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_REMOTE_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_UFS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_BYTES_WRITTEN_UFS_THROUGHPUT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_BLOCKS_SIZE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_FAILED_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_MANAGER_COMPLETED_TASK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_MANAGER_THREAD_ACTIVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_MANAGER_THREAD_CURRENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_MANAGER_THREAD_MAX_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_MANAGER_THREAD_QUEUE_WAITING_TASK_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_REMOTE_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_REQUESTS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_REQUESTS_ASYNC - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_REQUESTS_SYNC - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_SUCCEEDED_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CACHE_UFS_BLOCKS - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CAPACITY_FREE - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CAPACITY_TOTAL - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CAPACITY_USED - Static variable in class alluxio.metrics.MetricKey
 
WORKER_CLIENT - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
WORKER_CLIENT - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_CONTAINER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_CONTAINER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA - alluxio.util.network.NetworkAddressUtils.ServiceType
Worker data service (Netty).
WORKER_DATA_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_FOLDER - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_FOLDER - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_FOLDER_PERMISSIONS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_FOLDER_PERMISSIONS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_PORT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_SERVER_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_SERVER_CLASS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_ADDRESS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_ADDRESS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_AS_UUID - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_SERVER_DOMAIN_SOCKET_AS_UUID - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_TMP_FOLDER - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_TMP_FOLDER - Static variable in class alluxio.conf.PropertyKey
 
WORKER_DATA_TMP_SUBDIR_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_DATA_TMP_SUBDIR_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_ENCRYPTION_ZONE_INFO_SYNC - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
WORKER_EVICTOR_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_EVICTOR_CLASS - Static variable in class alluxio.conf.PropertyKey
Deprecated.
use block annotators instead
WORKER_FILE_BUFFER_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_FILE_BUFFER_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_FILESYSTEM_MASTER_SYNC - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
WORKER_FILESYSTEM_MASTER_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_FREE_SPACE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_FREE_SPACE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_FUSE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_FUSE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_FUSE_MOUNT_ALLUXIO_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_FUSE_MOUNT_OPTIONS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_FUSE_MOUNT_POINT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
WORKER_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_JVM_MONITOR_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_KEYTAB_FILE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_KEYTAB_FILE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MANAGEMENT_BACKOFF_STRATEGY - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MANAGEMENT_BACKOFF_STRATEGY - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MANAGEMENT_BLOCK_TRANSFER_CONCURRENCY_LIMIT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MANAGEMENT_BLOCK_TRANSFER_CONCURRENCY_LIMIT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MANAGEMENT_LOAD_DETECTION_COOL_DOWN_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MANAGEMENT_LOAD_DETECTION_COOL_DOWN_TIME - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MANAGEMENT_TASK_THREAD_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MANAGEMENT_TASK_THREAD_COUNT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MANAGEMENT_TIER_ALIGN_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MANAGEMENT_TIER_ALIGN_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MANAGEMENT_TIER_ALIGN_RANGE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MANAGEMENT_TIER_ALIGN_RANGE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MANAGEMENT_TIER_ALIGN_RESERVED_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MANAGEMENT_TIER_ALIGN_RESERVED_BYTES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MANAGEMENT_TIER_PROMOTE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MANAGEMENT_TIER_PROMOTE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MANAGEMENT_TIER_PROMOTE_QUOTA_PERCENT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MANAGEMENT_TIER_PROMOTE_QUOTA_PERCENT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MANAGEMENT_TIER_PROMOTE_RANGE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MANAGEMENT_TIER_PROMOTE_RANGE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MANAGEMENT_TIER_SWAP_RESTORE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MANAGEMENT_TIER_SWAP_RESTORE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MASTER_CONNECT_RETRY_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MASTER_CONNECT_RETRY_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MASTER_PERIODICAL_RPC_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_MASTER_PERIODICAL_RPC_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_MEMORY_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_ASYNC_CACHE_MANAGER_QUEUE_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_ASYNC_CACHE_MANAGER_QUEUE_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_ASYNC_CACHE_MANAGER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_ASYNC_CACHE_MANAGER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_BLOCK_READER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_BLOCK_READER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_BLOCK_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_BLOCK_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_FLOWCONTROL_WINDOW - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_KEEPALIVE_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_MAX_INBOUND_MESSAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_ASYNC_CACHE_MANAGER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_ASYNC_CACHE_MANAGER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_BACKLOG - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BACKLOG - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_BLOCK_READER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BLOCK_READER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_BLOCK_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BLOCK_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_BOSS_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BOSS_THREADS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_BUFFER_RECEIVE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BUFFER_RECEIVE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_BUFFER_SEND - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_BUFFER_SEND - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_CHANNEL - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_FILE_READER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_FILE_TRANSFER_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_FILE_TRANSFER_TYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_FILE_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_FILE_WRITER_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_READER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_READER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_RPC_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_RPC_THREADS_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_SHUTDOWN_QUIET_PERIOD - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_SHUTDOWN_QUIET_PERIOD - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_WATERMARK_HIGH - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WATERMARK_HIGH - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_WATERMARK_LOW - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WATERMARK_LOW - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WORKER_THREADS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_NETTY_WRITER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_NETTY_WRITER_BUFFER_SIZE_PACKETS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_PERMIT_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_PERMIT_KEEPALIVE_TIME_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_READER_BUFFER_POOLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_READER_BUFFER_POOLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_READER_BUFFER_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_READER_BUFFER_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_READER_MAX_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_READER_MAX_CHUNK_SIZE_BYTES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_SHUTDOWN_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_WRITER_BUFFER_SIZE_MESSAGES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_NETWORK_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_NETWORK_ZEROCOPY_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_ASYNC_RESTORE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_ASYNC_RESTORE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_ASYNC_WRITE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_ASYNC_WRITE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_ASYNC_WRITE_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_ASYNC_WRITE_THREADS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_DIRS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_DIRS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_EVICTION_RETRIES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_EVICTION_RETRIES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_EVICTOR_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_EVICTOR_CLASS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_EVICTOR_LFU_LOGBASE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_EVICTOR_LFU_LOGBASE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_EVICTOR_NONDETERMINISTIC_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_EVICTOR_NONDETERMINISTIC_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_LOCAL_STORE_FILE_BUCKETS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_LOCAL_STORE_FILE_BUCKETS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_OVERHEAD - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_OVERHEAD - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_PAGE_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_PAGE_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_QUOTA_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_QUOTA_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_SIZES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_SIZES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_TIMEOUT_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_TIMEOUT_DURATION - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_TIMEOUT_THREADS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_TIMEOUT_THREADS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PAGE_STORE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PAGE_STORE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_PIN_LIST_SYNC - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
WORKER_PIN_LIST_SYNC - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_PRINCIPAL - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_PRINCIPAL - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RAMDISK_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RAMDISK_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_LEASE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_LEASE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_LEASE_RETRY_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_LEASE_RETRY_MAX_DURATION - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_LEASE_RETRY_SLEEP_MAX - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_LEASE_RETRY_SLEEP_MAX - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_LEASE_RETRY_SLEEP_MIN - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_LEASE_RETRY_SLEEP_MIN - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_STREAM_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_STREAM_BATCH_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_STREAM_COMPLETE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_STREAM_COMPLETE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_STREAM_DEADLINE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_STREAM_DEADLINE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_STREAM_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_STREAM_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REGISTER_STREAM_RESPONSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REGISTER_STREAM_RESPONSE_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REMOTE_IO_SLOW_THRESHOLD - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REMOTE_IO_SLOW_THRESHOLD - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REVIEWER_CLASS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REVIEWER_CLASS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REVIEWER_PROBABILISTIC_HARDLIMIT_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REVIEWER_PROBABILISTIC_HARDLIMIT_BYTES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_REVIEWER_PROBABILISTIC_SOFTLIMIT_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_REVIEWER_PROBABILISTIC_SOFTLIMIT_BYTES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC - alluxio.util.network.NetworkAddressUtils.ServiceType
Worker RPC service (gRPC).
WORKER_RPC_EXECUTOR_CORE_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_CORE_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_FJP_ASYNC - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_FJP_ASYNC - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_FJP_MIN_RUNNABLE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_FJP_MIN_RUNNABLE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_FJP_PARALLELISM - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_FJP_PARALLELISM - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_KEEPALIVE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_KEEPALIVE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_MAX_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_MAX_POOL_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_TPE_ALLOW_CORE_THREADS_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_TPE_ALLOW_CORE_THREADS_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_TPE_QUEUE_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_TPE_QUEUE_TYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_EXECUTOR_TYPE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_EXECUTOR_TYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_RPC_PORT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_RPC_QUEUE_LENGTH - Static variable in class alluxio.metrics.MetricKey
 
WORKER_RPC_THREAD_ACTIVE_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_RPC_THREAD_CURRENT_COUNT - Static variable in class alluxio.metrics.MetricKey
 
WORKER_SESSION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_SESSION_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_SPACE_RESERVER - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
WORKER_SPACE_RESERVER - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_STARTUP_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_STARTUP_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_STORAGE_CHECKER_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_STORAGE_CHECKER_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_STORAGE_HEALTH - alluxio.heartbeat.HeartbeatContext.HeartbeatType
 
WORKER_STORAGE_HEALTH - Static variable in class alluxio.heartbeat.HeartbeatContext
 
WORKER_TIERED_STORE_BLOCK_LOCK_READERS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_TIERED_STORE_BLOCK_LOCK_READERS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_BLOCK_LOCKS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_TIERED_STORE_BLOCK_LOCKS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_FREE_AHEAD_BYTES - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_TIERED_STORE_FREE_AHEAD_BYTES - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL_ALIAS - alluxio.conf.PropertyKey.Template
 
WORKER_TIERED_STORE_LEVEL_DIRS_MEDIUMTYPE - alluxio.conf.PropertyKey.Template
 
WORKER_TIERED_STORE_LEVEL_DIRS_PATH - alluxio.conf.PropertyKey.Template
 
WORKER_TIERED_STORE_LEVEL_DIRS_QUOTA - alluxio.conf.PropertyKey.Template
 
WORKER_TIERED_STORE_LEVEL_HIGH_WATERMARK_RATIO - alluxio.conf.PropertyKey.Template
 
WORKER_TIERED_STORE_LEVEL_LOW_WATERMARK_RATIO - alluxio.conf.PropertyKey.Template
 
WORKER_TIERED_STORE_LEVEL0_ALIAS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_DIRS_MEDIUMTYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_DIRS_PATH - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_DIRS_QUOTA - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_HIGH_WATERMARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL0_LOW_WATERMARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_ALIAS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_DIRS_MEDIUMTYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_DIRS_PATH - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_DIRS_QUOTA - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_HIGH_WATERMARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL1_LOW_WATERMARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_ALIAS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_DIRS_MEDIUMTYPE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_DIRS_PATH - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_DIRS_QUOTA - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_HIGH_WATERMARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVEL2_LOW_WATERMARK_RATIO - Static variable in class alluxio.conf.PropertyKey
 
WORKER_TIERED_STORE_LEVELS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_TIERED_STORE_LEVELS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_UFS_BLOCK_OPEN_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_UFS_BLOCK_OPEN_TIMEOUT_MS - Static variable in class alluxio.conf.PropertyKey
 
WORKER_UFS_INSTREAM_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_UFS_INSTREAM_CACHE_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
WORKER_UFS_INSTREAM_CACHE_EXPIRARTION_TIME - Static variable in class alluxio.conf.PropertyKey
 
WORKER_UFS_INSTREAM_CACHE_EXPIRATION_TIME - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_UFS_INSTREAM_CACHE_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_UFS_INSTREAM_CACHE_MAX_SIZE - Static variable in class alluxio.conf.PropertyKey
 
WORKER_WEB - alluxio.util.network.NetworkAddressUtils.ServiceType
Worker web service (Jetty).
WORKER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_WEB_BIND_HOST - Static variable in class alluxio.conf.PropertyKey
 
WORKER_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_WEB_HOSTNAME - Static variable in class alluxio.conf.PropertyKey
 
WORKER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_WEB_PORT - Static variable in class alluxio.conf.PropertyKey
 
WORKER_WHITELIST - Static variable in class alluxio.conf.PropertyKey.Name
 
WORKER_WHITELIST - Static variable in class alluxio.conf.PropertyKey
 
workerEventLoopGroup(EventLoopGroup) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the worker EventLoopGroup.
WorkerInfo - Class in alluxio.wire
The worker information.
WorkerInfo() - Constructor for class alluxio.wire.WorkerInfo
 
WorkerInfo.LastContactSecComparator - Class in alluxio.wire
Determine order from most recently contacted to least recently contacted.
WorkerNetAddress - Class in alluxio.wire
The network address of a worker.
WorkerNetAddress() - Constructor for class alluxio.wire.WorkerNetAddress
Creates a new instance of WorkerNetAddress.
WorkerOutOfSpaceException - Exception in alluxio.exception
The exception thrown when a worker is out of space.
WorkerOutOfSpaceException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.WorkerOutOfSpaceException
Constructs a new exception with the specified exception message and multiple parameters.
WorkerOutOfSpaceException(ExceptionMessage, Throwable, Object...) - Constructor for exception alluxio.exception.WorkerOutOfSpaceException
Constructs a new exception with the specified exception message, the cause and multiple parameters.
WorkerOutOfSpaceException(String) - Constructor for exception alluxio.exception.WorkerOutOfSpaceException
Constructs a new exception with the specified detail message.
WorkerOutOfSpaceException(String, Throwable) - Constructor for exception alluxio.exception.WorkerOutOfSpaceException
Constructs a new exception with the specified detail message and cause.
WorkerWebUIBlockInfo - Class in alluxio.wire
Alluxio WebUI overview information.
WorkerWebUIBlockInfo() - Constructor for class alluxio.wire.WorkerWebUIBlockInfo
Creates a new instance of WorkerWebUIBlockInfo.
WorkerWebUIConfiguration - Class in alluxio.wire
Alluxio WebUI configuration information.
WorkerWebUIConfiguration() - Constructor for class alluxio.wire.WorkerWebUIConfiguration
Creates a new instance of WorkerWebUIConfiguration.
WorkerWebUIInit - Class in alluxio.wire
Alluxio WebUI overview information.
WorkerWebUIInit() - Constructor for class alluxio.wire.WorkerWebUIInit
Creates a new instance of WorkerWebUIInit.
WorkerWebUILogs - Class in alluxio.wire
Alluxio WebUI logs information.
WorkerWebUILogs() - Constructor for class alluxio.wire.WorkerWebUILogs
Creates a new instance of MasterWebUIWorkers.
WorkerWebUIMetrics - Class in alluxio.wire
Alluxio WebUI overview information.
WorkerWebUIMetrics() - Constructor for class alluxio.wire.WorkerWebUIMetrics
Creates a new instance of WorkerWebUIMetrics.
WorkerWebUIOverview - Class in alluxio.wire
Alluxio WebUI overview information.
WorkerWebUIOverview() - Constructor for class alluxio.wire.WorkerWebUIOverview
Creates a new instance of WorkerWebUIOverview.
wrap(byte[], int, int) - Method in class alluxio.security.authentication.plain.PlainSaslServer
 
write(byte[]) - Method in class alluxio.underfs.AtomicFileOutputStream
 
write(byte[]) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.AtomicFileOutputStream
 
write(byte[], int, int) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
write(int) - Method in class alluxio.underfs.AtomicFileOutputStream
 
write(int) - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
WRITE - alluxio.concurrent.LockMode
 
WRITE - alluxio.security.authorization.AclAction
 
WRITE - alluxio.security.authorization.Mode.Bits
 
WRITE_EXECUTE - alluxio.security.authorization.Mode.Bits
 
writeBufferToFile(String, byte[]) - Static method in class alluxio.util.io.BufferUtils
Writes buffer to the given file path.
writeByte(byte[], int, byte) - Static method in class alluxio.util.io.ByteIOUtils
Writes a single byte value (1 byte) to the output byte array at the given offset.
writeByte(OutputStream, byte) - Static method in class alluxio.util.io.ByteIOUtils
Writes a single byte value (1 byte) to the output stream.
writeByte(ByteBuffer, int, byte) - Static method in class alluxio.util.io.ByteIOUtils
Writes a single byte value (1 byte) to the output byte buffer at the given offset.
writeBytes(byte[], int, int) - Method in class alluxio.file.ByteArrayTargetBuffer
 
writeBytes(byte[], int, int) - Method in class alluxio.file.ByteBufferTargetBuffer
 
writeBytes(byte[], int, int) - Method in class alluxio.file.NettyBufTargetBuffer
 
writeBytes(byte[], int, int) - Method in interface alluxio.file.ReadTargetBuffer
 
writeBytes(ByteBuf) - Method in class alluxio.file.ByteArrayTargetBuffer
 
writeBytes(ByteBuf) - Method in class alluxio.file.ByteBufferTargetBuffer
 
writeBytes(ByteBuf) - Method in class alluxio.file.NettyBufTargetBuffer
 
writeBytes(ByteBuf) - Method in interface alluxio.file.ReadTargetBuffer
 
writeInt(byte[], int, int) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific integer value (4 bytes) to the output byte array at the given offset.
writeInt(OutputStream, int) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific integer value (4 bytes) to the output stream.
writeInt(ByteBuffer, int, int) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific integer value (4 bytes) to the output byte buffer at the given offset.
writeLock() - Method in class alluxio.concurrent.ClientRWLock
 
writeLong(byte[], int, long) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific long value (8 bytes) to the output byte array at the given offset.
writeLong(OutputStream, long) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific long value (8 bytes) to the output stream.
WRITER - alluxio.worker.block.io.BlockClient.Type
 
WriteRequestMarshaller - Class in alluxio.grpc
Marshaller for WriteRequest.
WriteRequestMarshaller() - Constructor for class alluxio.grpc.WriteRequestMarshaller
writeShort(byte[], int, short) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific short value (2 bytes) to the output byte buffer at the given offset.
writeShort(OutputStream, short) - Static method in class alluxio.util.io.ByteIOUtils
Writes a specific short value (2 bytes) to the output stream.
WriteType - Enum in alluxio.client
Write types for creating a file in Alluxio.

Z

ZkMasterConnectDetails(String, String) - Constructor for class alluxio.master.ZkMasterInquireClient.ZkMasterConnectDetails
 
ZkMasterInquireClient - Class in alluxio.master
Utility to get leader from zookeeper.
ZkMasterInquireClient.ZkMasterConnectDetails - Class in alluxio.master
Details used to connect to the leader Alluxio master via Zookeeper.
ZOOKEEPER_ADDRESS - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_ADDRESS - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_AUTH - Static variable in interface alluxio.uri.Authority
 
ZOOKEEPER_AUTH_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_AUTH_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_CONNECTION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_ELECTION_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_ELECTION_PATH - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_ENABLED - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_ENABLED - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_JOB_ELECTION_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_JOB_ELECTION_PATH - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_JOB_LEADER_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_JOB_LEADER_PATH - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_LEADER_CONNECTION_ERROR_POLICY - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_LEADER_CONNECTION_ERROR_POLICY - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_LEADER_INQUIRY_RETRY_COUNT - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_LEADER_INQUIRY_RETRY_COUNT - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_LEADER_PATH - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_LEADER_PATH - Static variable in class alluxio.conf.PropertyKey
 
ZOOKEEPER_SESSION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey.Name
 
ZOOKEEPER_SESSION_TIMEOUT - Static variable in class alluxio.conf.PropertyKey
 
ZookeeperAuthority - Class in alluxio.uri
ZookeeperAuthority supports authority containing Zookeeper addresses.
ZookeeperAuthority(String) - Constructor for class alluxio.uri.ZookeeperAuthority
 
ZookeeperConnectionErrorPolicy - Enum in alluxio.master
Defines supported connection error policies for leader election.
ZookeeperLogicalAuthority - Class in alluxio.uri
A zookeeper logical host authority implementation.
ZookeeperLogicalAuthority(String) - Constructor for class alluxio.uri.ZookeeperLogicalAuthority
 
A B C D E F G H I J K L M N O P Q R S T U V W Z 
All Classes All Packages