Skip navigation links
A B C D E F G H I J K L M N O P Q R S T U V W X Z 

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_COSTMAP - Static variable in class alluxio.master.metrics.CloudCostUtils
 
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
 
AbfsUnderFileSystem - Class in alluxio.underfs.abfs
A Microsoft Azure Data Lake Storage Gen2 Implementation.
AbfsUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.abfs.AbfsUnderFileSystem
Constructs a new HDFS UnderFileSystem.
AbfsUnderFileSystemFactory - Class in alluxio.underfs.abfs
Factory for creating AbfsUnderFileSystem.
AbfsUnderFileSystemFactory() - Constructor for class alluxio.underfs.abfs.AbfsUnderFileSystemFactory
Constructs a new AbfsUnderFileSystemFactory.
abort(String) - Method in interface alluxio.client.file.cache.PageStore
Abort a temporary file.
abort(String) - Method in class alluxio.client.file.cache.store.LocalPageStore
 
abort(String) - Method in interface alluxio.client.file.cache.store.PageStoreDir
Abort a temporary file.
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).
abort() - Method in interface alluxio.underfs.MultipartUploader
Aborts a multipart upload.
abort() - Method in class alluxio.worker.block.io.BlockWriter
Abort writing.
abort() - Method in class alluxio.worker.dora.PagedFileWriter
 
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.
ABORTED_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
Aborted indicates the operation was aborted, typically due to a concurrency issue like sequencer check failures, transaction aborts, etc.
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(Throwable) - Constructor for exception alluxio.exception.status.AbortedException
 
AbortedException(String, Throwable) - Constructor for exception alluxio.exception.status.AbortedException
 
abortMultiPartUpload() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
abortMultiPartUpload() - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
abortMultipartUploadInternal() - Method in class alluxio.underfs.cos.COSMultipartUploadOutputStream
 
abortMultiPartUploadInternal() - Method in class alluxio.underfs.ObjectLowLevelOutputStream
 
abortMultipartUploadInternal() - Method in class alluxio.underfs.ObjectMultipartUploadOutputStream
 
abortMultiPartUploadInternal() - Method in class alluxio.underfs.obs.OBSLowLevelOutputStream
 
abortMultipartUploadInternal() - Method in class alluxio.underfs.obs.OBSMultipartUploadOutputStream
 
abortMultiPartUploadInternal() - Method in class alluxio.underfs.oss.OSSLowLevelOutputStream
 
abortMultipartUploadInternal() - Method in class alluxio.underfs.oss.OSSMultipartUploadOutputStream
 
abortMultiPartUploadInternal() - Method in class alluxio.underfs.s3a.S3ALowLevelOutputStream
 
abortMultipartUploadInternal() - Method in class alluxio.underfs.s3a.S3AMultipartUploadOutputStream
 
AbortTask(FileSystem, FileSystem, String, String, String) - Constructor for class alluxio.proxy.s3.MultipartUploadCleaner.AbortTask
Creates a new instance of MultipartUploadCleaner.AbortTask.
AbstractBackupRole - Class in alluxio.master.backup
Abstract backup role implementation.
AbstractBackupRole(CoreMasterContext) - Constructor for class alluxio.master.backup.AbstractBackupRole
Creates a BackupMaster.
AbstractCatchupThread - Class in alluxio.master.journal
Abstract helper for tracking and terminating a thread for journal catch-up task.
AbstractCatchupThread() - Constructor for class alluxio.master.journal.AbstractCatchupThread
Constructor.
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, boolean) - Constructor for class alluxio.AbstractClient
 
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
AbstractCmdRunner - Class in alluxio.master.job.tracker
The base class for all the distributed job runner classes.
AbstractCmdRunner(FileSystemContext, JobMaster) - Constructor for class alluxio.master.job.tracker.AbstractCmdRunner
 
AbstractCollectInfoCommand - Class in alluxio.cli.bundler.command
Abstraction of a command under CollectInfo.
AbstractCollectInfoCommand(FileSystemContext) - Constructor for class alluxio.cli.bundler.command.AbstractCollectInfoCommand
Creates an instance of AbstractCollectInfoCommand.
AbstractDistributedJobCommand - Class in alluxio.cli.fs.command
The base class for all the distributed job based Command classes.
AbstractDistributedJobCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.AbstractDistributedJobCommand
 
AbstractExtendedAttribute<T> - Class in alluxio.master.file.meta.xattr
Extend this class to implement any extended attributes.
AbstractFileSystem - Class in alluxio.hadoop
Base class for Apache Hadoop based Alluxio FileSystem.
AbstractFileSystem(FileSystem) - Constructor for class alluxio.hadoop.AbstractFileSystem
Constructs a new AbstractFileSystem instance with specified a FileSystem handler for tests.
AbstractFileSystem() - Constructor for class alluxio.hadoop.AbstractFileSystem
Constructs a new AbstractFileSystem instance.
AbstractFileSystemCommand - Class in alluxio.cli.fs.command
The base class for all the FileSystem Command classes.
AbstractFileSystemCommand(FileSystemContext) - Constructor for class alluxio.cli.fs.command.AbstractFileSystemCommand
 
AbstractFsAdminCommand - Class in alluxio.cli.fsadmin.command
Base class for fsadmin commands.
AbstractFsAdminCommand(Context) - Constructor for class alluxio.cli.fsadmin.command.AbstractFsAdminCommand
 
AbstractFuseFileSystem - Class in alluxio.jnifuse
Abstract class for other File System to extend and integrate with Fuse.
AbstractFuseFileSystem(Path) - Constructor for class alluxio.jnifuse.AbstractFuseFileSystem
Constructs an AbstractFuseFileSystem.
AbstractFuseShellCommand - Class in alluxio.cli.command
The base class for all the Fuse FuseCommand classes.
AbstractFuseShellCommand(FileSystem, AlluxioConfiguration, String) - Constructor for class alluxio.cli.command.AbstractFuseShellCommand
 
AbstractJob<T extends Task<?>> - Class in alluxio.master.job
Abstract class for job.
AbstractJob(Optional<String>, String) - Constructor for class alluxio.master.job.AbstractJob
Creates a new instance of AbstractJob.
AbstractJob(Optional<String>, String, WorkerAssignPolicy) - Constructor for class alluxio.master.job.AbstractJob
Creates a new instance of AbstractJob.
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.
AbstractJournalDumper - Class in alluxio.master.journal.tool
An abstract class for journal dumpers.
AbstractJournalDumper(String, long, long, String, String) - Constructor for class alluxio.master.journal.tool.AbstractJournalDumper
 
AbstractJournalProgressLogger - Class in alluxio.master.journal
Class to abstract out progress logging for journal replay.
AbstractJournalProgressLogger(OptionalLong) - Constructor for class alluxio.master.journal.AbstractJournalProgressLogger
Creates a new instance of AbstractJournalProgressLogger.
AbstractJournalSystem - Class in alluxio.master.journal
Base implementation for journal systems.
AbstractJournalSystem() - Constructor for class alluxio.master.journal.AbstractJournalSystem
 
AbstractLocalAlluxioCluster - Class in alluxio.master
Local Alluxio cluster.
AbstractMaster - Class in alluxio.master
This is the base class for all masters, and contains common functionality.
AbstractMaster(MasterContext, Clock, ExecutorServiceFactory) - Constructor for class alluxio.master.AbstractMaster
 
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.
AbstractMasterClient(MasterClientContext, MasterSelectionPolicy, 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
 
AbstractMetadataCacheSubCommand - Class in alluxio.cli.command.metadatacache
Metadata cache sub command.
AbstractMetadataCacheSubCommand(FileSystem, AlluxioConfiguration, String) - Constructor for class alluxio.cli.command.metadatacache.AbstractMetadataCacheSubCommand
 
AbstractPrimarySelector - Class in alluxio.master
Base class for implementing primary selectors.
AbstractPrimarySelector() - Constructor for class alluxio.master.AbstractPrimarySelector
 
AbstractReadHandler<T extends ReadRequest> - Class in alluxio.worker.netty
This class handles Protocol.ReadRequests.
AbstractReadHandler(ExecutorService, Channel, Class<T>, AbstractReadHandler.PacketReader.Factory<T, ? extends AbstractReadHandler.PacketReader<T>>) - Constructor for class alluxio.worker.netty.AbstractReadHandler
Creates an instance of AbstractReadHandler.
AbstractReadHandler.PacketReader<T extends ReadRequest> - Interface in alluxio.worker.netty
A runnable that reads packets and writes them to the channel.
AbstractReadHandler.PacketReader.Factory<T extends ReadRequest,P extends AbstractReadHandler.PacketReader<T>> - Interface in alluxio.worker.netty
Factory that creates a PacketReader.
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.
AbstractStressBench<T extends TaskResult,P extends FileSystemParameters> - Class in alluxio.stress.cli
An abstraction for stress tests which generates a specific workload on a certain Alluxio component (master, worker, ClientIO).
AbstractStressBench() - Constructor for class alluxio.stress.cli.AbstractStressBench
 
AbstractUfsManager - Class in alluxio.underfs
Basic implementation of UfsManager.
AbstractUfsManager() - Constructor for class alluxio.underfs.AbstractUfsManager
 
AbstractUfsManager.Key - Class in alluxio.underfs
The key of the UFS cache.
AbstractValidationTask - Class in alluxio.cli
Abstract class for validation environment.
AbstractValidationTask() - Constructor for class alluxio.cli.AbstractValidationTask
 
AbstractVoidPlanDefinition<T extends JobConfig,P extends Serializable> - Class in alluxio.job.plan
An abstract job definition where the run task method does not return a value.
AbstractVoidPlanDefinition() - Constructor for class alluxio.job.plan.AbstractVoidPlanDefinition
 
AbstractWorker - Class in alluxio.worker
This is the base class for all workers, and contains common functionality.
AbstractWorker(ExecutorServiceFactory) - Constructor for class alluxio.worker.AbstractWorker
 
accept(T) - Method in class alluxio.master.transport.Listeners
Accepts an event.
accept(T) - Method in class alluxio.master.transport.Listeners.ListenerHolder
 
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>, Executor) - 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 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
 
acceptMessage(Object) - Method in class alluxio.worker.netty.AbstractReadHandler
Checks whether this object should be processed by this handler.
acceptMessage(Object) - Method in class alluxio.worker.netty.FileWriteHandler
 
acceptMessage(Object) - Method in class alluxio.worker.netty.UfsFileWriteHandler
 
access(Path, FsAction) - Method in class alluxio.hadoop.AbstractFileSystem
 
ACCESS_ACL_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
ACCESS_DENIED_ERROR - Static variable in class alluxio.s3.S3ErrorCode
 
ACCESS_DENIED_ERROR - Static variable in class alluxio.s3.S3ErrorCode.Name
 
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(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.
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.
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.
ACCESSMODE_FIELD_NUMBER - Static variable in class alluxio.grpc.GetStatusPOptions
 
Acl - Class in alluxio.proto.shared
 
Acl.AccessControlList - Class in alluxio.proto.shared
next available id: 9
Acl.AccessControlList.Builder - Class in alluxio.proto.shared
next available id: 9
Acl.AccessControlListOrBuilder - Interface in alluxio.proto.shared
 
Acl.AclAction - Enum in alluxio.proto.shared
next available id: 3
Acl.AclActions - Class in alluxio.proto.shared
next available id: 2
Acl.AclActions.Builder - Class in alluxio.proto.shared
next available id: 2
Acl.AclActionsOrBuilder - Interface in alluxio.proto.shared
 
Acl.AclEntry - Class in alluxio.proto.shared
next available id: 5
Acl.AclEntry.Builder - Class in alluxio.proto.shared
next available id: 5
Acl.AclEntryOrBuilder - Interface in alluxio.proto.shared
 
Acl.AclEntryType - Enum in alluxio.proto.shared
next available id: 6
Acl.NamedAclActions - Class in alluxio.proto.shared
AclActions for a String name.
Acl.NamedAclActions.Builder - Class in alluxio.proto.shared
AclActions for a String name.
Acl.NamedAclActionsOrBuilder - Interface in alluxio.proto.shared
 
ACL_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
ACL_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions
 
ACL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeDirectoryEntry
 
ACL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
ACL_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeEntry
 
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(int) - Static method in class alluxio.network.protocol.databuffer.NioDirectBufferPool
 
acquire() - Method in class alluxio.resource.DynamicResourcePool
Acquires a resource of type {code T} from the pool.
acquire(long, TimeUnit) - 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(long, TimeUnit) - 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(long, TimeUnit) - Method in class alluxio.resource.ResourcePool
Acquires an object of type {code T} from the pool.
acquire(UnderFileSystem, String, FileId, OpenOptions) - Method in class alluxio.underfs.UfsInputStreamCache
Acquires an input stream.
acquire() - Method in interface alluxio.util.RateLimiter
Acquire a permit for the next operation.
acquire() - Method in class alluxio.util.SimpleRateLimiter
 
acquireBlockMasterClientResource() - Method in class alluxio.client.file.FileSystemContext
Acquires a block master client resource from the block master client pool.
acquireBlockWorkerClient(WorkerNetAddress) - Method in class alluxio.client.file.FileSystemContext
Acquires a block worker client from the client pools.
acquireChannel(GrpcNetworkGroup, GrpcServerAddress, AlluxioConfiguration, boolean) - 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.
acquireMasterClient() - Method in class alluxio.client.job.JobContext
Acquires a job master client from the job master client pool.
acquireMasterClientResource() - Method in class alluxio.client.file.FileSystemContext
Acquires a file system master client from the file system master client pool.
acquireMasterClientResource() - Method in class alluxio.client.job.JobContext
Acquires a job master client from the job master client pool.
acquireNettyChannel(WorkerNetAddress) - Method in class alluxio.client.file.FileSystemContext
Acquires a netty channel from the channel pools.
acquireRegisterLeaseWithBackoff(long, int, RetryPolicy) - Method in class alluxio.worker.block.BlockMasterClient
Acquires a RegisterLease from the master with the RetryPolicy specified.
acquireUfsResource() - Method in class alluxio.master.file.meta.MountTable.Resolution
 
acquireUfsResource() - Method in class alluxio.underfs.UfsManager.UfsClient
 
ACTION_FIELD_NUMBER - Static variable in class alluxio.grpc.SetAclPRequest
 
ACTION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.SetAclEntry
 
ACTIONID_FIELD_NUMBER - Static variable in class alluxio.grpc.ActionInfo
 
ACTIONID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetActionInfoRequest
 
ActionInfo - Class in alluxio.grpc
next available id: 7
ActionInfo.Builder - Class in alluxio.grpc
next available id: 7
ActionInfoOrBuilder - Interface in alluxio.grpc
 
ACTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.PAclEntry
 
ACTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AclActions
 
ACTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.AclEntry
 
ACTIONS_FIELD_NUMBER - Static variable in class alluxio.proto.shared.Acl.NamedAclActions
 
ACTIONSCANCELED_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
 
ACTIONSFAILED_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
 
ACTIONSRUNNING_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
 
ACTIONSSCHEDULED_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
 
ACTIONSSUCCEEDED_FIELD_NUMBER - Static variable in class alluxio.grpc.PolicyStatus
 
ACTIONSTATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.ActionInfo
 
ACTIONTYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.ActionInfo
 
ACTIVE_SYNC_TX_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
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) - Method in class alluxio.client.file.cache.cuckoofilter.SizeEncoder
Adds a new size to the encoder.
add(T) - Method in class alluxio.collections.ConcurrentHashSet
 
add(T) - Method in class alluxio.collections.DelegatingSet
 
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(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(int, T) - Method in class alluxio.collections.UnmodifiableArrayList
 
add(TimeSeries) - Method in class alluxio.job.util.TimeSeries
Add one histogram to the current one.
add(Journal.JournalEntry) - Method in class alluxio.master.file.FileSystemJournalEntryMerger
Adds a new journal entry and merges it on the fly.
add(Supplier<JournalContext>, AlluxioURI, AlluxioURI, long, MountPOptions) - Method in class alluxio.master.file.meta.MountTable
Mounts the given UFS path at the given Alluxio path.
add(Journal.JournalEntry) - Method in interface alluxio.master.journal.JournalEntryMerger
Adds a new journal entry.
add(Supplier<JournalContext>, String, Map<PropertyKey, String>) - Method in class alluxio.master.meta.PathProperties
Adds properties for path.
add(long) - Method in class alluxio.master.predicate.interval.Interval
Add an offset to the interval.
add(Consumer<T>) - Method in class alluxio.master.transport.Listeners
Adds a new listener.
add(Class<W>, T) - Method in class alluxio.Registry
Registers a canonical mapping of the type to the server instance.
add(AclAction) - Method in class alluxio.security.authorization.AclActions
Adds a permitted action.
add(T) - Method in class alluxio.underfs.ObjectUnderFileSystem.OperationBuffer
Adds a new input to be operated on.
add(long, T) - Method in class alluxio.util.executor.ControllableQueue
Adds a new node into the queue.
add(String, OpenFileHandle) - Method in class alluxio.worker.dora.DoraOpenFileHandleContainer
Add a open file handle into this collection.
ADD_MOUNT_POINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
ADD_SYNC_POINT_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
addAction(AclAction) - Method in class alluxio.security.authorization.AclEntry.Builder
Adds a permitted action.
addActions(PAclAction) - Method in class alluxio.grpc.PAclEntry.Builder
repeated .alluxio.grpc.file.PAclAction actions = 3;
addActions(Acl.AclAction) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
repeated .alluxio.proto.shared.AclAction actions = 1;
addActions(Acl.AclAction) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
repeated .alluxio.proto.shared.AclAction actions = 3;
addAddedBlocks(LocationBlockIdListEntry) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addAddedBlocks(int, LocationBlockIdListEntry) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addAddedBlocks(LocationBlockIdListEntry.Builder) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addAddedBlocks(int, LocationBlockIdListEntry.Builder) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addAddedBlocksBuilder() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addAddedBlocksBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addAdditionalResult(long, long) - Method in class alluxio.stress.cli.client.StressClientIOBench
Read the log file from java agent log file.
addAddresses(String) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
addresses are only valid when workerRange is SPECIFIED
addAddressesBytes(ByteString) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
addresses are only valid when workerRange is SPECIFIED
addAffectedPaths(String) - Method in class alluxio.grpc.JobInfo.Builder
repeated string affectedPaths = 14;
addAffectedPathsBytes(ByteString) - Method in class alluxio.grpc.JobInfo.Builder
repeated string affectedPaths = 14;
addAggregator(MultiValueMetricsAggregator) - Method in class alluxio.master.metrics.DefaultMetricsMaster
 
addAlias(Class<W>, T) - Method in class alluxio.Registry
Registers a server instance under an alias type.
addAll(Collection<? extends T>) - Method in class alluxio.collections.DelegatingSet
 
addAll(Collection<? extends T>) - Method in class alluxio.collections.UnmodifiableArrayList
 
addAll(int, Collection<? extends T>) - Method in class alluxio.collections.UnmodifiableArrayList
 
addAllActions(Iterable<? extends PAclAction>) - Method in class alluxio.grpc.PAclEntry.Builder
repeated .alluxio.grpc.file.PAclAction actions = 3;
addAllActions(Iterable<? extends Acl.AclAction>) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
repeated .alluxio.proto.shared.AclAction actions = 1;
addAllActions(Iterable<? extends Acl.AclAction>) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
repeated .alluxio.proto.shared.AclAction actions = 3;
addAllAddedBlocks(Iterable<? extends LocationBlockIdListEntry>) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addAllAddresses(Iterable<String>) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
addresses are only valid when workerRange is SPECIFIED
addAllAffectedPaths(Iterable<String>) - Method in class alluxio.grpc.JobInfo.Builder
repeated string affectedPaths = 14;
addAllBlockId(Iterable<? extends Long>) - Method in class alluxio.grpc.BlockIdList.Builder
repeated int64 blockId = 1;
addAllBlockIds(Iterable<? extends Long>) - Method in class alluxio.grpc.FileInfo.Builder
repeated int64 blockIds = 13;
addAllBlockIds(Iterable<? extends Long>) - Method in class alluxio.grpc.PersistFile.Builder
repeated int64 blockIds = 2;
addAllBlockIds(Iterable<? extends Long>) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
repeated int64 block_ids = 1;
addAllBlocks(Iterable<? extends Block>) - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
addAllBlocks(Iterable<? extends Long>) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated int64 blocks = 12;
addAllBlocks(Iterable<? extends Long>) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated int64 blocks = 16;
addAllBlockStatus(Iterable<? extends BlockStatus>) - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
addAllBucketedBy(Iterable<String>) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated string bucketed_by = 1;
addAllCandidates(Iterable<? extends Value>) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
addAllChildren(Iterable<? extends JobInfo>) - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
addAllClientMetrics(Iterable<? extends ClientMetrics>) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
addAllClusterConfigs(Iterable<? extends ConfigProperty>) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
addAllColNames(Iterable<String>) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string col_names = 3;
addAllColNames(Iterable<String>) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
repeated string col_names = 3;
addAllCols(Iterable<? extends FieldSchema>) - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
addAllCommands(Iterable<? extends JobCommand>) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
addAllConfigs(Iterable<? extends ConfigProperty>) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addAllConfigs(Iterable<? extends ConfigProperty>) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addAllCurrentBlocks(Iterable<? extends LocationBlockIdListEntry>) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addAllData(Iterable<? extends Long>) - Method in class alluxio.grpc.Command.Builder
repeated int64 data = 2;
addAllDatabase(Iterable<String>) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
repeated string database = 1;
addAllDataCols(Iterable<? extends FieldSchema>) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
addAllEntries(Iterable<? extends PAclEntry>) - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
addAllEntries(Iterable<? extends PAclEntry>) - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
addAllEntries(Iterable<? extends Acl.AclEntry>) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
addAllFailures(Iterable<? extends RouteFailure>) - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addAllFailures(Iterable<? extends LoadFileFailure>) - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
addAllFailures(Iterable<? extends RouteFailure>) - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addAllFieldRanges(Iterable<? extends WorkerInfoField>) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
addAllFileBlockInfos(Iterable<? extends FileBlockInfo>) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
addAllFileInfos(Iterable<? extends FileInfo>) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addAllFileInfos(Iterable<? extends FileInfo>) - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addAllFilter(Iterable<? extends MasterInfoField>) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
addAllFilters(Iterable<? extends BlockMasterInfoField>) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
addAllGroupActions(Iterable<? extends Acl.NamedAclActions>) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
addAllInconsistentPaths(Iterable<String>) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
repeated string inconsistentPaths = 1;
addAllInfo(Iterable<? extends TransformJobInfo>) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
addAllInfos(Iterable<? extends ActionInfo>) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
addAllJobIds(Iterable<? extends Long>) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated int64 jobIds = 1;
addAllJobInfos(Iterable<? extends JobInfo>) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
addAllJobMasterStatus(Iterable<? extends JobMasterStatus>) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
addAllJobProgress(Iterable<? extends JobProgress>) - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
addAllJobStatusBlock(Iterable<? extends JobStatusBlock>) - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
addAllJournalEntries(Iterable<? extends Journal.JournalEntry>) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
addAllKeys(Iterable<String>) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
repeated string keys = 2;
addAllLoadAverage(Iterable<? extends Double>) - Method in class alluxio.grpc.JobWorkerHealth.Builder
repeated double loadAverage = 2;
addAllLocations(Iterable<? extends BlockLocation>) - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
addAllLongestRunning(Iterable<? extends JobInfo>) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
addAllMasterAddresses(Iterable<? extends NetAddress>) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
addAllMasterVersions(Iterable<? extends MasterVersion>) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
addAllMediumType(Iterable<String>) - Method in class alluxio.grpc.FileInfo.Builder
repeated string mediumType = 33;
addAllMediumType(Iterable<String>) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
repeated string medium_type = 18;
addAllMediumType(Iterable<String>) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated string medium_type = 26;
addAllMediumType(Iterable<String>) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
repeated string medium_type = 16;
addAllMediumType(Iterable<String>) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated string medium_type = 27;
addAllMetrics(Iterable<? extends Metric>) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
addAllMetrics(Iterable<? extends Metric>) - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
addAllPartitionCols(Iterable<? extends FieldSchema>) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
addAllPartitions(Iterable<? extends Partition>) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
addAllPartNames(Iterable<String>) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string part_names = 4;
addAllPersistedFileFingerprints(Iterable<String>) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
repeated string persistedFileFingerprints = 1;
addAllPersistedFiles(Iterable<? extends Long>) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
the list of persisted files
addAllPersistFiles(Iterable<? extends PersistFile>) - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
addAllPinnedFileIds(Iterable<? extends Long>) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
TODO(adit): set replacement?
addAllPinnedMedia(Iterable<String>) - Method in class alluxio.grpc.SetAttributePOptions.Builder
repeated string pinnedMedia = 10;
addAllPolicy(Iterable<? extends PolicyInfo>) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
addAllProperties(Iterable<? extends ConfigProperty>) - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
addAllProperties(Iterable<? extends InconsistentProperty>) - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
addAllProperties(Iterable<? extends File.StringPairEntry>) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
addAllProxyStatuses(Iterable<? extends ProxyStatus>) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
addAllRaftAddress(Iterable<String>) - Method in class alluxio.grpc.MasterInfo.Builder
repeated string raftAddress = 13;
addAllRanges(Iterable<? extends Range>) - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
addAllRecentActivities(Iterable<? extends JobInfo>) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
addAllRecentFailures(Iterable<? extends JobInfo>) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
addAllRemovedBlockIds(Iterable<? extends Long>) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the list of removed block ids
addAllRoutes(Iterable<? extends Route>) - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addAllRoutes(Iterable<? extends Route>) - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addAllServerInfo(Iterable<? extends QuorumServerInfo>) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
addAllSetBlocks(Iterable<? extends Long>) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
Overwrite the blocks list
addAllSortedBy(Iterable<? extends SortingColumn>) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
addAllStatistics(Iterable<? extends ColumnStatisticsInfo>) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addAllStatistics(Iterable<? extends ColumnStatisticsInfo>) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addAllStatus(Iterable<? extends Status>) - Method in class alluxio.grpc.ListAllPOptions.Builder
repeated .alluxio.grpc.job.Status status = 1;
addAllStorage(Iterable<String>) - Method in class alluxio.grpc.StorageList.Builder
a lost storage path
addAllStorageTiers(Iterable<String>) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the list of storage tiers
addAllSummaryPerStatus(Iterable<? extends StatusSummary>) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
addAllTable(Iterable<String>) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
repeated string table = 1;
addAllTablesIgnored(Iterable<String>) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_ignored = 2;
addAllTablesRemoved(Iterable<String>) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_removed = 5;
addAllTablesUnchanged(Iterable<String>) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_unchanged = 3;
addAllTablesUpdated(Iterable<String>) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_updated = 4;
addAllTaskInfos(Iterable<? extends JobInfo>) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
addAllThreads(Iterable<String>) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
repeated string threads = 1;
addAllTiers(Iterable<? extends Long>) - Method in class alluxio.grpc.TierList.Builder
repeated int64 tiers = 1;
addAllTransformations(Iterable<? extends Transformation>) - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
addAllUfsLocations(Iterable<? extends WorkerNetAddress>) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
addAllUfsStatus(Iterable<? extends UfsStatus>) - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
addAllUfsStringLocations(Iterable<String>) - Method in class alluxio.grpc.FileBlockInfo.Builder
repeated string ufsStringLocations = 4;
addAllUnused0(Iterable<? extends JobUnused>) - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
addAllUserActions(Iterable<? extends Acl.NamedAclActions>) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
addAllValues(Iterable<String>) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
repeated string values = 1;
addAllValues(Iterable<String>) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
list of string values for each partition column
addAllWorkerAddresses(Iterable<? extends NetAddress>) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
addAllWorkerHealths(Iterable<? extends JobWorkerHealth>) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
addAllWorkerInfos(Iterable<? extends WorkerInfo>) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
addAllWorkerLostStorageInfo(Iterable<? extends WorkerLostStorageInfo>) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
addAllZookeeperAddresses(Iterable<String>) - Method in class alluxio.grpc.MasterInfo.Builder
Empty means zookeeper is not enabled
addBlock(long) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Adds a block to the worker.
addBlock(String, long, long, long) - Method in class alluxio.util.webui.UIFileInfo
Adds a block to the file information.
addBlockFailure(Block, String, int) - Method in class alluxio.master.job.LoadJob
Add a block to failure summary.
addBlockId(long) - Method in class alluxio.grpc.BlockIdList.Builder
repeated int64 blockId = 1;
addBlockIds(long) - Method in class alluxio.grpc.FileInfo.Builder
repeated int64 blockIds = 13;
addBlockIds(long) - Method in class alluxio.grpc.PersistFile.Builder
repeated int64 blockIds = 2;
addBlockIds(long) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
repeated int64 block_ids = 1;
addBlockMeta(BlockMeta) - Method in interface alluxio.worker.block.meta.StorageDir
Adds the metadata of a new block into this storage dir.
addBlocks(Block) - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
addBlocks(int, Block) - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
addBlocks(Block.Builder) - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
addBlocks(int, Block.Builder) - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
addBlocks(long) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated int64 blocks = 12;
addBlocks(long) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated int64 blocks = 16;
addBlocksBuilder() - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
addBlocksBuilder(int) - Method in class alluxio.grpc.LoadRequest.Builder
repeated .alluxio.grpc.block.Block blocks = 1;
addBlockStatus(BlockStatus) - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
addBlockStatus(int, BlockStatus) - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
addBlockStatus(BlockStatus.Builder) - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
addBlockStatus(int, BlockStatus.Builder) - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
addBlockStatusBuilder() - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
addBlockStatusBuilder(int) - Method in class alluxio.grpc.LoadResponse.Builder
repeated .alluxio.grpc.block.BlockStatus block_status = 2;
addBlockToRetry(Block) - Method in class alluxio.master.job.LoadJob
Add a block to retry later.
addBucketedBy(String) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated string bucketed_by = 1;
addBucketedByBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated string bucketed_by = 1;
addBuffersToStream(ByteBuf[], OutputStream) - Static method in class alluxio.grpc.GrpcSerializationUtils
Add the given buffers directly to the gRPC output stream.
addCandidates(Value) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
addCandidates(int, Value) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
addCandidates(Value.Builder) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
addCandidates(int, Value.Builder) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
addCandidatesBuilder() - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
addCandidatesBuilder(int) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
repeated .alluxio.grpc.table.Value candidates = 1;
addChild(DirectedAcyclicGraphNode<T>) - Method in class alluxio.collections.DirectedAcyclicGraphNode
Adds a child node to the node.
addChild(long, String, Long) - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
addChild(long, String, Long) - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
addChild(long, String, Long) - Method in interface alluxio.master.metastore.InodeStore
Makes an inode the child of the specified parent.
addChild(long, InodeView) - Method in interface alluxio.master.metastore.InodeStore
Makes an inode the child of the specified parent.
addChild(Long, String, Long) - Method in interface alluxio.master.metastore.InodeStore.WriteBatch
Adds an edge to the write batch.
addChild(long, String, Long) - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
addChildren(JobInfo) - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
addChildren(int, JobInfo) - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
addChildren(JobInfo.Builder) - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
addChildren(int, JobInfo.Builder) - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
addChildren(String, String, byte[]) - Method in class alluxio.membership.AlluxioEtcdClient
Create a childPath with value to a parentPath.
addChildren(AlluxioURI, Collection<UfsStatus>) - Method in class alluxio.underfs.UfsStatusCache
Add a parent-child mapping to the status cache.
addChildrenBuilder() - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
addChildrenBuilder(int) - Method in class alluxio.grpc.JobInfo.Builder
repeated .alluxio.grpc.job.JobInfo children = 11;
addChildrenListener(String, StateListener) - Method in class alluxio.membership.AlluxioEtcdClient
Add state listener to watch children for given path.
addClientMetrics(ClientMetrics) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
addClientMetrics(int, ClientMetrics) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
addClientMetrics(ClientMetrics.Builder) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
addClientMetrics(int, ClientMetrics.Builder) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
addClientMetricsBuilder() - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
addClientMetricsBuilder(int) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
repeated .alluxio.grpc.metric.ClientMetrics clientMetrics = 1;
addClusterConfigs(ConfigProperty) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
addClusterConfigs(int, ConfigProperty) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
addClusterConfigs(ConfigProperty.Builder) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
addClusterConfigs(int, ConfigProperty.Builder) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
addClusterConfigsBuilder() - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
addClusterConfigsBuilder(int) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
repeated .alluxio.grpc.ConfigProperty clusterConfigs = 1;
addClusterProperty(String, Object, Source) - Method in class alluxio.wire.Configuration.Builder
Adds a cluster level property.
addCmdRunAttempt(CmdRunAttempt) - Method in class alluxio.master.job.common.CmdInfo
Add the CmdRunAttempt.
addColNames(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string col_names = 3;
addColNames(String) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
repeated string col_names = 3;
addColNamesBytes(ByteString) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string col_names = 3;
addColNamesBytes(ByteString) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
repeated string col_names = 3;
addCols(FieldSchema) - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
addCols(int, FieldSchema) - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
addCols(FieldSchema.Builder) - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
addCols(int, FieldSchema.Builder) - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
addColsBuilder() - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
addColsBuilder(int) - Method in class alluxio.grpc.table.Schema.Builder
repeated .alluxio.grpc.table.FieldSchema cols = 1;
addCommands(JobCommand) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
addCommands(int, JobCommand) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
addCommands(JobCommand.Builder) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
addCommands(int, JobCommand.Builder) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
addCommandsBuilder() - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
addCommandsBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
repeated .alluxio.grpc.job.JobCommand commands = 1;
addConfigs(ConfigProperty) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addConfigs(int, ConfigProperty) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addConfigs(ConfigProperty.Builder) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addConfigs(int, ConfigProperty.Builder) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addConfigs(ConfigProperty) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addConfigs(int, ConfigProperty) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addConfigs(ConfigProperty.Builder) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addConfigs(int, ConfigProperty.Builder) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addConfigsBuilder() - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addConfigsBuilder(int) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addConfigsBuilder() - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addConfigsBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
repeated .alluxio.grpc.ConfigProperty configs = 1;
addContent(HttpContent) - Method in class alluxio.worker.s3.S3NettyHandler
Adds content to the content queue.
addCopiedBytes(long) - Method in class alluxio.master.job.CopyJob
Add bytes to total loaded bytes.
addCurrentBlocks(LocationBlockIdListEntry) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addCurrentBlocks(int, LocationBlockIdListEntry) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addCurrentBlocks(LocationBlockIdListEntry.Builder) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addCurrentBlocks(int, LocationBlockIdListEntry.Builder) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addCurrentBlocksBuilder() - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addCurrentBlocksBuilder(int) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
use repeated fields to represent mapping from BlockStoreLocationProto to TierList
addData(long) - Method in class alluxio.grpc.Command.Builder
repeated int64 data = 2;
addData(Object) - Method in class alluxio.stress.graph.BarGraph.Data
 
addData(Object, Object) - Method in class alluxio.stress.graph.LineGraph.Data
 
addDatabase(String) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
repeated string database = 1;
addDatabaseBytes(ByteString) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
repeated string database = 1;
addDataCols(FieldSchema) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
addDataCols(int, FieldSchema) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
addDataCols(FieldSchema.Builder) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
addDataCols(int, FieldSchema.Builder) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
addDataColsBuilder() - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
addDataColsBuilder(int) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
repeated .alluxio.grpc.table.FieldSchema data_cols = 6;
addDataPoint(WorkerBenchDataPoint) - Method in class alluxio.stress.worker.WorkerBenchCoarseDataPoint
 
addDataPoint(WorkerBenchCoarseDataPoint) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
addDataPoints(Collection<WorkerBenchCoarseDataPoint>) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
addDataSeries(String, BarGraph.Data) - Method in class alluxio.stress.graph.BarGraph
 
addDataSeries(String, LineGraph.Data) - Method in class alluxio.stress.graph.LineGraph
 
ADDEDBLOCKS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPRequest
 
ADDEDBLOCKSONTIERS_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockHeartbeatPRequest
 
addEntries(PAclEntry) - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
addEntries(int, PAclEntry) - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
addEntries(PAclEntry.Builder) - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
addEntries(int, PAclEntry.Builder) - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
addEntries(PAclEntry) - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
addEntries(int, PAclEntry) - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
addEntries(PAclEntry.Builder) - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
addEntries(int, PAclEntry.Builder) - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
addEntries(Acl.AclEntry) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
addEntries(int, Acl.AclEntry) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
addEntries(Acl.AclEntry.Builder) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
addEntries(int, Acl.AclEntry.Builder) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
addEntriesBuilder() - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
addEntriesBuilder(int) - Method in class alluxio.grpc.PAcl.Builder
repeated .alluxio.grpc.file.PAclEntry entries = 3;
addEntriesBuilder() - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
addEntriesBuilder(int) - Method in class alluxio.grpc.SetAclPRequest.Builder
the list of ACL entries
addEntriesBuilder() - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
addEntriesBuilder(int) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
repeated .alluxio.proto.shared.AclEntry entries = 4;
addError(String) - Method in class alluxio.stress.worker.IOTaskResult
 
addErrorMessage(String) - Method in class alluxio.stress.client.ClientIOTaskResult.ThreadCountResult
 
addErrorMessage(String) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
addExternalMasterAddress(MasterNetAddress) - Method in class alluxio.multi.process.MultiProcessCluster
Updates internal master list with an external address.
addFailure(String, String, int) - Method in class alluxio.master.job.CopyJob
Add a block to failure summary.
addFailure(String, String, int) - Method in class alluxio.master.job.MoveJob
Add a block to failure summary.
addFailures(RouteFailure) - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addFailures(int, RouteFailure) - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addFailures(RouteFailure.Builder) - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addFailures(int, RouteFailure.Builder) - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addFailures(LoadFileFailure) - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
addFailures(int, LoadFileFailure) - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
addFailures(LoadFileFailure.Builder) - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
addFailures(int, LoadFileFailure.Builder) - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
addFailures(RouteFailure) - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addFailures(int, RouteFailure) - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addFailures(RouteFailure.Builder) - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addFailures(int, RouteFailure.Builder) - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addFailuresBuilder() - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addFailuresBuilder(int) - Method in class alluxio.grpc.CopyResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addFailuresBuilder() - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
addFailuresBuilder(int) - Method in class alluxio.grpc.LoadFileResponse.Builder
repeated .alluxio.grpc.block.LoadFileFailure failures = 2;
addFailuresBuilder() - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addFailuresBuilder(int) - Method in class alluxio.grpc.MoveResponse.Builder
repeated .alluxio.grpc.block.RouteFailure failures = 2;
addFieldRanges(WorkerInfoField) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
repeated .alluxio.grpc.block.WorkerInfoField fieldRanges = 2;
addFileBlockInfos(FileBlockInfo) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
addFileBlockInfos(int, FileBlockInfo) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
addFileBlockInfos(FileBlockInfo.Builder) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
addFileBlockInfos(int, FileBlockInfo.Builder) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
addFileBlockInfosBuilder() - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
addFileBlockInfosBuilder(int) - Method in class alluxio.grpc.FileInfo.Builder
repeated .alluxio.grpc.file.FileBlockInfo fileBlockInfos = 21;
addFileFailure(String, String, String) - Method in class alluxio.master.job.DoraLoadJob
Add failed files.
addFileInfos(FileInfo) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addFileInfos(int, FileInfo) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addFileInfos(FileInfo.Builder) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addFileInfos(int, FileInfo.Builder) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addFileInfos(FileInfo) - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addFileInfos(int, FileInfo) - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addFileInfos(FileInfo.Builder) - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addFileInfos(int, FileInfo.Builder) - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addFileInfosBuilder() - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addFileInfosBuilder(int) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addFileInfosBuilder() - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addFileInfosBuilder(int) - Method in class alluxio.grpc.ListStatusPResponse.Builder
repeated .alluxio.grpc.file.FileInfo fileInfos = 1;
addFilesToRetry(String, String, String) - Method in class alluxio.master.job.DoraLoadJob
Add files to retry.
addFilter(MasterInfoField) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
repeated .alluxio.grpc.meta.MasterInfoField filter = 1;
addFilters(BlockMasterInfoField) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
repeated .alluxio.grpc.block.BlockMasterInfoField filters = 1;
addGroupActions(Acl.NamedAclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
addGroupActions(int, Acl.NamedAclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
addGroupActions(Acl.NamedAclActions.Builder) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
addGroupActions(int, Acl.NamedAclActions.Builder) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
addGroupActionsBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
addGroupActionsBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions groupActions = 4;
addHandler(AbstractHandler) - Method in class alluxio.web.WebServer
Adds a handler.
addHeartbeat(ClientContext, MasterInquireClient) - Static method in class alluxio.client.metrics.MetricsHeartbeatContext
Sets up a new metrics heartbeat with the given client information.
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.
addInconsistentPaths(String) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
repeated string inconsistentPaths = 1;
addInconsistentPathsBytes(ByteString) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
repeated string inconsistentPaths = 1;
addInfo(TransformJobInfo) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
addInfo(int, TransformJobInfo) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
addInfo(TransformJobInfo.Builder) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
addInfo(int, TransformJobInfo.Builder) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
addInfoBuilder() - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
addInfoBuilder(int) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
repeated .alluxio.grpc.table.TransformJobInfo info = 1;
addInfos(ActionInfo) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
addInfos(int, ActionInfo) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
addInfos(ActionInfo.Builder) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
addInfos(int, ActionInfo.Builder) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
addInfosBuilder() - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
addInfosBuilder(int) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
repeated .alluxio.grpc.policy.ActionInfo infos = 1;
addInnerValue(K1, K2, V) - Method in class alluxio.collections.TwoKeyConcurrentMap
 
addInode(Inode) - Method in class alluxio.master.file.meta.TtlBucket
Adds an inode with default num of retry attempt to expire.
addInode(Inode, int) - Method in class alluxio.master.file.meta.TtlBucket
Adds an inode to the bucket with a specific left retry number.
ADDITIONAL_OPTION_NAME - Static variable in class alluxio.cli.bundler.command.CollectLogCommand
 
addJobIds(long) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated int64 jobIds = 1;
addJobInfos(JobInfo) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
addJobInfos(int, JobInfo) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
addJobInfos(JobInfo.Builder) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
addJobInfos(int, JobInfo.Builder) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
addJobInfosBuilder() - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
addJobInfosBuilder(int) - Method in class alluxio.grpc.ListAllPResponse.Builder
repeated .alluxio.grpc.job.JobInfo jobInfos = 2;
addJobMasterStatus(JobMasterStatus) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
addJobMasterStatus(int, JobMasterStatus) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
addJobMasterStatus(JobMasterStatus.Builder) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
addJobMasterStatus(int, JobMasterStatus.Builder) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
addJobMasterStatusBuilder() - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
addJobMasterStatusBuilder(int) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
repeated .alluxio.grpc.job.JobMasterStatus jobMasterStatus = 1;
addJobProgress(JobProgress) - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
addJobProgress(int, JobProgress) - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
addJobProgress(JobProgress.Builder) - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
addJobProgress(int, JobProgress.Builder) - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
addJobProgressBuilder() - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
addJobProgressBuilder(int) - Method in class alluxio.grpc.CmdProgress.Builder
repeated .alluxio.grpc.job.JobProgress jobProgress = 1;
addJobStatusBlock(JobStatusBlock) - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
addJobStatusBlock(int, JobStatusBlock) - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
addJobStatusBlock(JobStatusBlock.Builder) - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
addJobStatusBlock(int, JobStatusBlock.Builder) - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
addJobStatusBlock(SimpleJobStatusBlock) - Method in class alluxio.job.wire.CmdStatusBlock
Add an entry of job status block.
addJobStatusBlockBuilder() - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
addJobStatusBlockBuilder(int) - Method in class alluxio.grpc.CmdStatusBlock.Builder
repeated .alluxio.grpc.job.JobStatusBlock jobStatusBlock = 2;
addJournalEntries(Journal.JournalEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
addJournalEntries(int, Journal.JournalEntry) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
addJournalEntries(Journal.JournalEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
addJournalEntries(int, Journal.JournalEntry.Builder) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
addJournalEntriesBuilder() - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
addJournalEntriesBuilder(int) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
This journal entry is a list of other entries.
addJournalSink(Master, JournalSink) - Method in class alluxio.master.journal.AbstractJournalSystem
 
addJournalSink(Master, JournalSink) - Method in interface alluxio.master.journal.JournalSystem
 
addJournalSink(Master, JournalSink) - Method in class alluxio.master.journal.noop.NoopJournalSystem
 
addKeys(String) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
repeated string keys = 2;
addKeysBytes(ByteString) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
repeated string keys = 2;
addLoadAverage(double) - Method in class alluxio.grpc.JobWorkerHealth.Builder
repeated double loadAverage = 2;
addLoadedBytes(long) - Method in class alluxio.master.job.DoraLoadJob
Add bytes to total loaded bytes.
addLoadedBytes(long) - Method in class alluxio.master.job.LoadJob
Add bytes to total loaded bytes.
addLocation(long, Block.BlockLocation) - Method in interface alluxio.master.metastore.BlockMetaStore
Adds a new block location.
addLocation(long, Block.BlockLocation) - Method in class alluxio.master.metastore.heap.HeapBlockMetaStore
 
addLocation(long, Block.BlockLocation) - Method in class alluxio.master.metastore.rocks.RocksBlockMetaStore
 
addLocations(BlockLocation) - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
addLocations(int, BlockLocation) - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
addLocations(BlockLocation.Builder) - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
addLocations(int, BlockLocation.Builder) - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
addLocationsBuilder() - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
addLocationsBuilder(int) - Method in class alluxio.grpc.BlockInfo.Builder
repeated .alluxio.grpc.BlockLocation locations = 3;
addLongestRunning(JobInfo) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
addLongestRunning(int, JobInfo) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
addLongestRunning(JobInfo.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
addLongestRunning(int, JobInfo.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
addLongestRunningBuilder() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
addLongestRunningBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo longestRunning = 4;
addLostStorage(Map<String, StorageList>) - Method in class alluxio.master.block.meta.MasterWorkerInfo
Adds new worker lost storage paths.
addMasterAddresses(NetAddress) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
addMasterAddresses(int, NetAddress) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
addMasterAddresses(NetAddress.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
addMasterAddresses(int, NetAddress.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
addMasterAddressesBuilder() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
addMasterAddressesBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress masterAddresses = 2;
addMasterVersions(MasterVersion) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
addMasterVersions(int, MasterVersion) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
addMasterVersions(MasterVersion.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
addMasterVersions(int, MasterVersion.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
addMasterVersionsBuilder() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
addMasterVersionsBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.meta.MasterVersion masterVersions = 14;
addMediumType(String) - Method in class alluxio.grpc.FileInfo.Builder
repeated string mediumType = 33;
addMediumType(String) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
repeated string medium_type = 18;
addMediumType(String) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated string medium_type = 26;
addMediumType(String) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
repeated string medium_type = 16;
addMediumType(String) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated string medium_type = 27;
addMediumTypeBytes(ByteString) - Method in class alluxio.grpc.FileInfo.Builder
repeated string mediumType = 33;
addMediumTypeBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
repeated string medium_type = 18;
addMediumTypeBytes(ByteString) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
repeated string medium_type = 26;
addMediumTypeBytes(ByteString) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
repeated string medium_type = 16;
addMediumTypeBytes(ByteString) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
repeated string medium_type = 27;
addMetrics(Metric) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
addMetrics(int, Metric) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
addMetrics(Metric.Builder) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
addMetrics(int, Metric.Builder) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
addMetrics(Metric) - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
addMetrics(int, Metric) - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
addMetrics(Metric.Builder) - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
addMetrics(int, Metric.Builder) - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
addMetricsBuilder() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
addMetricsBuilder(int) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
repeated .alluxio.grpc.Metric metrics = 1;
addMetricsBuilder() - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
addMetricsBuilder(int) - Method in class alluxio.grpc.ClientMetrics.Builder
repeated .alluxio.grpc.Metric metrics = 2;
addMount(long, AlluxioURI, UnderFileSystemConfiguration) - Method in class alluxio.underfs.AbstractUfsManager
 
addMount(long, AlluxioURI, UnderFileSystemConfiguration) - Method in class alluxio.underfs.MasterUfsManager
 
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 class alluxio.underfs.AbstractUfsManager
 
addMountWithRecorder(long, AlluxioURI, UnderFileSystemConfiguration, Recorder) - Method in class alluxio.underfs.MasterUfsManager
 
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.
addMovedBytes(long) - Method in class alluxio.master.job.MoveJob
Add bytes to total moved bytes.
addNextInode(Inode) - Method in class alluxio.master.file.meta.LockedInodePath
Adds the next inode to the path.
addPage(PageId, PageInfo) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
addPage(PageId, PageInfo) - Method in interface alluxio.client.file.cache.PageMetaStore
Adds a new page to the cache.
addPage(PageId, PageInfo) - Method in class alluxio.client.file.cache.QuotaPageMetaStore
 
addParent(DirectedAcyclicGraphNode<T>) - Method in class alluxio.collections.DirectedAcyclicGraphNode
Adds a parent node to the node.
addPartitionCols(FieldSchema) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
addPartitionCols(int, FieldSchema) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
addPartitionCols(FieldSchema.Builder) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
addPartitionCols(int, FieldSchema.Builder) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
addPartitionColsBuilder() - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
addPartitionColsBuilder(int) - Method in class alluxio.grpc.table.TableInfo.Builder
partitioning scheme
addPartitions(Partition) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
addPartitions(int, Partition) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
addPartitions(Partition.Builder) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
addPartitions(int, Partition.Builder) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
addPartitionsBuilder() - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
addPartitionsBuilder(int) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
repeated .alluxio.grpc.table.Partition partitions = 1;
addPartNames(String) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string part_names = 4;
addPartNamesBytes(ByteString) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
repeated string part_names = 4;
addPath(String) - Method in class alluxio.extensions.ExtensionsClassLoader
Adds a path where the class loader can load resource from.
addPathProperty(String, String, String) - Method in class alluxio.wire.Configuration.Builder
Adds a path level property.
addPersistedFileFingerprints(String) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
repeated string persistedFileFingerprints = 1;
addPersistedFileFingerprintsBytes(ByteString) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
repeated string persistedFileFingerprints = 1;
addPersistedFiles(long) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
the list of persisted files
addPersistFiles(PersistFile) - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
addPersistFiles(int, PersistFile) - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
addPersistFiles(PersistFile.Builder) - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
addPersistFiles(int, PersistFile.Builder) - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
addPersistFilesBuilder() - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
addPersistFilesBuilder(int) - Method in class alluxio.grpc.PersistCommandOptions.Builder
repeated .alluxio.grpc.file.PersistFile persistFiles = 1;
addPinnedFileIds(long) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
TODO(adit): set replacement?
addPinnedMedia(String) - Method in class alluxio.grpc.SetAttributePOptions.Builder
repeated string pinnedMedia = 10;
addPinnedMediaBytes(ByteString) - Method in class alluxio.grpc.SetAttributePOptions.Builder
repeated string pinnedMedia = 10;
addPoint(IOTaskResult.Point) - Method in class alluxio.stress.worker.IOTaskResult
 
addPolicy(PolicyInfo) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
addPolicy(int, PolicyInfo) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
addPolicy(PolicyInfo.Builder) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
addPolicy(int, PolicyInfo.Builder) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
addPolicy(AddPolicyPRequest, StreamObserver<AddPolicyPResponse>) - Method in interface alluxio.grpc.PolicyMasterClientServiceGrpc.AsyncService
Adds a new policy definition
addPolicy(AddPolicyPRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceBlockingStub
Adds a new policy definition
addPolicy(AddPolicyPRequest) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceFutureStub
Adds a new policy definition
addPolicy(AddPolicyPRequest, StreamObserver<AddPolicyPResponse>) - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceStub
Adds a new policy definition
addPolicyBuilder() - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
addPolicyBuilder(int) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
repeated .alluxio.grpc.policy.PolicyInfo policy = 1;
AddPolicyPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.AddPolicyPOptions
AddPolicyPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.AddPolicyPOptions
AddPolicyPOptionsOrBuilder - Interface in alluxio.grpc
 
AddPolicyPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.AddPolicyPRequest
AddPolicyPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.AddPolicyPRequest
AddPolicyPRequestOrBuilder - Interface in alluxio.grpc
 
AddPolicyPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.AddPolicyPResponse
AddPolicyPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.policy.AddPolicyPResponse
AddPolicyPResponseOrBuilder - Interface in alluxio.grpc
 
addProperties(ConfigProperty) - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
addProperties(int, ConfigProperty) - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
addProperties(ConfigProperty.Builder) - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
addProperties(int, ConfigProperty.Builder) - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
addProperties(InconsistentProperty) - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
addProperties(int, InconsistentProperty) - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
addProperties(InconsistentProperty.Builder) - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
addProperties(int, InconsistentProperty.Builder) - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
addProperties(Map<PropertyKey, Object>) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
addProperties(File.StringPairEntry) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
addProperties(int, File.StringPairEntry) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
addProperties(File.StringPairEntry.Builder) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
addProperties(int, File.StringPairEntry.Builder) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
addPropertiesBuilder() - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
addPropertiesBuilder(int) - Method in class alluxio.grpc.ConfigProperties.Builder
repeated .alluxio.grpc.ConfigProperty properties = 1;
addPropertiesBuilder() - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
addPropertiesBuilder(int) - Method in class alluxio.grpc.InconsistentProperties.Builder
repeated .alluxio.grpc.meta.InconsistentProperty properties = 1;
addPropertiesBuilder() - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
addPropertiesBuilder(int) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
repeated .alluxio.proto.journal.StringPairEntry properties = 4;
addProperty(PropertyKey, Object) - Method in class alluxio.multi.process.MultiProcessCluster.Builder
 
addProxy(InetSocketAddress, InetSocketAddress) - Method in class alluxio.master.transport.GrpcMessagingProxy
Adds a new proxy mapping.
addProxyStatuses(ProxyStatus) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
addProxyStatuses(int, ProxyStatus) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
addProxyStatuses(ProxyStatus.Builder) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
addProxyStatuses(int, ProxyStatus.Builder) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
addProxyStatusesBuilder() - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
addProxyStatusesBuilder(int) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
repeated .alluxio.grpc.meta.ProxyStatus proxyStatuses = 1;
addQuorumServer(NetAddress) - Method in class alluxio.master.journal.raft.RaftJournalSystem
Adds a server to the quorum.
AddQuorumServerRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.AddQuorumServerRequest
AddQuorumServerRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.AddQuorumServerRequest
ADDQUORUMSERVERREQUEST_FIELD_NUMBER - Static variable in class alluxio.grpc.JournalQueryRequest
 
AddQuorumServerRequestOrBuilder - Interface in alluxio.grpc
 
addRaftAddress(String) - Method in class alluxio.grpc.MasterInfo.Builder
repeated string raftAddress = 13;
addRaftAddressBytes(ByteString) - Method in class alluxio.grpc.MasterInfo.Builder
repeated string raftAddress = 13;
addRanges(Range) - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
addRanges(int, Range) - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
addRanges(Range.Builder) - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
addRanges(int, Range.Builder) - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
addRangesBuilder() - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
addRangesBuilder(int) - Method in class alluxio.grpc.table.RangeSet.Builder
repeated .alluxio.grpc.table.Range ranges = 1;
addRecentActivities(JobInfo) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
addRecentActivities(int, JobInfo) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
addRecentActivities(JobInfo.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
addRecentActivities(int, JobInfo.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
addRecentActivitiesBuilder() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
addRecentActivitiesBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentActivities = 2;
addRecentFailures(JobInfo) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
addRecentFailures(int, JobInfo) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
addRecentFailures(JobInfo.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
addRecentFailures(int, JobInfo.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
addRecentFailuresBuilder() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
addRecentFailuresBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.JobInfo recentFailures = 3;
addReference() - Method in class alluxio.concurrent.ClientRWLock
Increments the reference count.
addRemovedBlockIds(long) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
the list of removed block ids
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ActionInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupPStatus.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Block.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockIdList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockLocation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockStatus.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.BuildVersion.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CacheRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CacheResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CheckResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Chunk.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ClientMetrics.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CmdProgress.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CmdSummary.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Command.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CommitBlockPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CompleteFilePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CompleteFilePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CompleteFilePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ConfigCheckReport.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ConfigProperties.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ConfigProperty.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CopyJobPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CopyRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CopyResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateDirectoryPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateDirectoryPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateDirectoryPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateFilePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateFilePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.CreateFilePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DecommissionWorkerPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DecommissionWorkerPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DeletePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DeletePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DeletePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DownloadSnapshotPRequest.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.DownloadSnapshotPResponse.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ErrorInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ExistsPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ExistsPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ExistsPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.File.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileBlockInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileFailure.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemCommand.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemCommandOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemHeartbeatPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FileSystemMasterCommonPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreeWorkerRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FreeWorkerResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.FsOpPId.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetActionInfoOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetActionInfoRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetActionInfoResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllMasterStatusPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllMasterStatusPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllMasterStatusPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockInfoPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockInfoPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockInfoPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockMasterInfoPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetBlockMasterInfoPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCapacityBytesPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCapacityBytesPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusDetailedResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetCmdStatusResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigHashPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigHashPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigReportPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigReportPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigurationPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetConfigurationPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFileInfoPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFileInfoPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFileInfoPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFilePathPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetFilePathPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobMasterIdPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobMasterIdPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobMasterIdPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobProgressPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobProgressPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobServiceSummaryPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusDetailedPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetJobStatusPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterIdPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterIdPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterIdPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterInfoPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMasterInfoPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMetricsPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMetricsPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMountIdPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMountIdPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMountTablePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetMountTablePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNewBlockIdForFilePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNodeStatePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetNodeStatePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPinnedFileIdsPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPolicyStatusPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPolicyStatusPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetPolicyStatusPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetQuorumInfoPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetQuorumInfoPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetRegisterLeasePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetRegisterLeasePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetRegisterLeasePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetServiceVersionPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetServiceVersionPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSnapshotInfoRequest.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSnapshotInfoResponse.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetSnapshotRequest.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStateLockHoldersPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStateLockHoldersPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStatusPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStatusPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetStatusPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetTransferLeaderMessageOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetTransferLeaderMessagePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetTransferLeaderMessagePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUfsInfoPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUfsInfoPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUfsInfoPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUsedBytesPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetUsedBytesPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerIdPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerIdPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerIdPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerInfoListPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerLostStoragePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.GetWorkerReportPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.InconsistentProperties.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.InconsistentProperty.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobCommand.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobDescription.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobHeartbeatPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobHeartbeatPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobMasterHeartbeatPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobMasterStatus.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobProgress.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobProgressPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobServiceSummary.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobStatusBlock.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobUnused.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JobWorkerHealth.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JournalQueryRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.JournalQueryResponse.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LatestSnapshotInfoPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListAllPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListAllPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListAllPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListPolicyPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListPolicyPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListPolicyPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListProxyStatusPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListProxyStatusPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListProxyStatusPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPartialPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPartialPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPartialPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ListStatusPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadFileFailure.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadFileRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadFileResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadJobPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadMetadataPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LoadResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.LocationBlockIdListEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterHeartbeatPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterHeartbeatPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterHeartbeatPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MasterVersion.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MessagingRequestHeader.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MessagingResponseHeader.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Metric.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MetricsHeartbeatPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MetricsHeartbeatPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MetricsHeartbeatPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MetricValue.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MountPointInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MountPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MountPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MountPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveBlockRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveBlockResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveJobPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.MoveResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NeedsSyncRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NeedsSyncResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NetAddress.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NotifyWorkerIdPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NotifyWorkerIdPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.NotifyWorkerIdPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.OpenFilePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PAcl.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PAclEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PersistCommandOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PersistFile.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PMode.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PolicyInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.PolicyStatus.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ProxyHeartbeatPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ProxyHeartbeatPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ProxyHeartbeatPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ProxyStatus.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.QuorumServerInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReadRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReadResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterCommand.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobMasterPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobMasterPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobMasterPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobWorkerPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobWorkerPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterJobWorkerPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterMasterPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterMasterPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterMasterPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterWorkerPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RegisterWorkerPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveBlockRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveBlockResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveDisabledWorkerPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveDisabledWorkerPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePathConfigurationPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePathConfigurationPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePathConfigurationPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePolicyPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePolicyPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemovePolicyPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveQuorumServerPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveQuorumServerPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RemoveQuorumServerPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RenamePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RenamePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RenamePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ResetPrioritiesPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ResetPrioritiesPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ResetPrioritiesPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RetryInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReverseResolvePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ReverseResolvePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.Route.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RouteFailure.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RunPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RunPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RunPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.RunTaskCommand.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.S3SyntaxOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SaslMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.ScheduleAsyncPersistencePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAclPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAclPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAclPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAttributePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAttributePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetAttributePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetPathConfigurationPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetPathConfigurationPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetPathConfigurationPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SetTaskPoolSizeCommand.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SnapshotData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SnapshotMetadata.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StatusSummary.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StopJobPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StopJobPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.StorageList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitJobPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitJobPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.SubmitResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.AllOrNoneSet.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.AttachDatabasePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.AttachDatabasePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.BinaryColumnStatsData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.BooleanColumnStatsData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ColumnStatisticsData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ColumnStatisticsInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Constraint.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Database.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Date.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DateColumnStatsData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Decimal.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DecimalColumnStatsData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DetachDatabasePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DetachDatabasePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Domain.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.DoubleColumnStatsData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.EquatableValueSet.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.FieldSchema.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.FileStatistics.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetAllDatabasesPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetAllDatabasesPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetAllTablesPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetDatabasePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetDatabasePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetPartitionColumnStatisticsPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTablePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTablePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTransformJobInfoPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.GetTransformJobInfoPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Layout.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.SortingColumn.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.Storage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.layout.hive.StorageFormat.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.LayoutSpec.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.LongColumnStatsData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Partition.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.PartitionSpec.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Range.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.RangeSet.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ReadTablePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.ReadTablePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Schema.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.StringColumnStatsData.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.SyncDatabasePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.SyncDatabasePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.SyncStatus.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.TableInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Transformation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.TransformJobInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.TransformTablePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.TransformTablePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.table.Value.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TierList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeaderMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeadershipPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeadershipPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransferLeadershipPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TransportMessage.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TriggerPolicyRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.TriggerPolicyResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsFileStatus.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsReadOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UfsStatus.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UnmountPOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UnmountPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UnmountPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateConfigurationPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateConfigurationPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateMountPRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateMountPResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateUfsModePOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateUfsModePRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UpdateUfsModePResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UploadSnapshotPRequest.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.UploadSnapshotPResponse.Builder
Deprecated.
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WorkerIdentity.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WorkerInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WorkerLostStorageInfo.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WorkerNetAddress.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WriteOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WriteRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WriteRequestCommand.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.grpc.WriteResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.client.Cache.PPageStoreCommonOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.client.Cache.PRocksPageStoreOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.CreateUfsFileOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.Heartbeat.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockCreateResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.LocalBlockOpenResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.ReadRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.ReadResponse.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.Response.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.dataserver.Protocol.WriteRequest.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Block.BlockContainerIdGeneratorEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Block.BlockInfoEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Block.DeleteBlockEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.ActiveSyncTxIdEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.AddMountPointEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.AddSyncPointEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.AsyncPersistRequestEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.CompleteFileEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.DeleteFileEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.DeleteMountPointEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.InodeDirectoryEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.InodeDirectoryIdGeneratorEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.InodeFileEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.InodeLastModificationTimeEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.NewBlockEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.PersistDirectoryEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.PersistFileEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.RemoveSyncPointEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.RenameEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.SetAclEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.SetAttributeEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.StringPairEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.UpdateInodeDirectoryEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.UpdateInodeEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.File.UpdateUfsModeEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Job.CopyJobEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Job.FileFilter.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Job.LoadJobEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Job.MoveJobEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Journal.JournalEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Journal.JournalOpPId.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Meta.ClusterInfoEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Meta.PathPropertiesEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Meta.RemovePathPropertiesEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Policy.PolicyDefinitionEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.journal.Policy.PolicyRemoveEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.meta.Block.BlockLocation.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.meta.Block.BlockMeta.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.meta.DoraMeta.FileStatus.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.meta.InodeMeta.Inode.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.shared.Acl.AclActions.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.shared.Acl.AclEntry.Builder
 
addRepeatedField(Descriptors.FieldDescriptor, Object) - Method in class alluxio.proto.shared.Acl.NamedAclActions.Builder
 
Address - Class in alluxio.wire
The address of a node.
Address() - Constructor for class alluxio.wire.Address
Creates a new instance of Address.
Address(String, int) - 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_FIELD_NUMBER - Static variable in class alluxio.grpc.ProxyStatus
 
ADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerInfo
 
ADDRESS_FIELD_NUMBER - Static variable in class alluxio.grpc.WorkerLostStorageInfo
 
ADDRESS_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.journal.QuorumElectCommand
 
ADDRESS_OPTION_NAME - Static variable in class alluxio.cli.fsadmin.journal.QuorumRemoveCommand
 
ADDRESS_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
ADDRESS = 1;
ADDRESSES_FIELD_NUMBER - Static variable in class alluxio.grpc.GetWorkerReportPOptions
 
ADDRESSES_FIELD_NUMBER - Static variable in class alluxio.grpc.MasterVersion
 
addRoutes(Route) - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addRoutes(int, Route) - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addRoutes(Route.Builder) - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addRoutes(int, Route.Builder) - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addRoutes(Route) - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addRoutes(int, Route) - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addRoutes(Route.Builder) - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addRoutes(int, Route.Builder) - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addRoutesBuilder() - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addRoutesBuilder(int) - Method in class alluxio.grpc.CopyRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addRoutesBuilder() - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addRoutesBuilder(int) - Method in class alluxio.grpc.MoveRequest.Builder
repeated .alluxio.grpc.block.Route routes = 1;
addServerInfo(QuorumServerInfo) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
addServerInfo(int, QuorumServerInfo) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
addServerInfo(QuorumServerInfo.Builder) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
addServerInfo(int, QuorumServerInfo.Builder) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
addServerInfoBuilder() - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
addServerInfoBuilder(int) - Method in class alluxio.grpc.GetQuorumInfoPResponse.Builder
repeated .alluxio.grpc.journal.QuorumServerInfo serverInfo = 2;
addService(ServiceType, GrpcService) - Method in class alluxio.grpc.GrpcServerBuilder
Add a service to this server.
addService(GrpcService) - Method in class alluxio.grpc.GrpcServerBuilder
Add a service to this server.
addSetBlocks(long) - Method in class alluxio.proto.journal.File.UpdateInodeFileEntry.Builder
Overwrite the blocks list
addSinglePath(AlluxioURI) - Method in class alluxio.master.file.meta.AsyncUfsAbsentPathCache
 
addSinglePath(AlluxioURI) - Method in class alluxio.master.file.meta.NoopUfsAbsentPathCache
 
addSinglePath(AlluxioURI) - Method in interface alluxio.master.file.meta.UfsAbsentPathCache
Add a single path to the absent cache synchronously.
addSkip() - Method in class alluxio.master.job.CopyJob
Add a skip to metrics.
addSortedBy(SortingColumn) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
addSortedBy(int, SortingColumn) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
addSortedBy(SortingColumn.Builder) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
addSortedBy(int, SortingColumn.Builder) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
addSortedByBuilder() - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
addSortedByBuilder(int) - Method in class alluxio.grpc.table.layout.hive.HiveBucketProperty.Builder
repeated .alluxio.grpc.table.layout.SortingColumn sorted_by = 3;
addStateListener(String, StateListener) - Method in class alluxio.membership.AlluxioEtcdClient
Add state listener to given path.
addStatistics(ColumnStatisticsInfo) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addStatistics(int, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addStatistics(ColumnStatisticsInfo.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addStatistics(int, ColumnStatisticsInfo.Builder) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addStatistics(ColumnStatisticsInfo) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addStatistics(int, ColumnStatisticsInfo) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addStatistics(ColumnStatisticsInfo.Builder) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addStatistics(int, ColumnStatisticsInfo.Builder) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addStatisticsBuilder() - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addStatisticsBuilder(int) - Method in class alluxio.grpc.table.ColumnStatisticsList.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addStatisticsBuilder() - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addStatisticsBuilder(int) - Method in class alluxio.grpc.table.GetTableColumnStatisticsPResponse.Builder
repeated .alluxio.grpc.table.ColumnStatisticsInfo statistics = 1;
addStatus(Status) - Method in class alluxio.grpc.ListAllPOptions.Builder
repeated .alluxio.grpc.job.Status status = 1;
addStatus(AlluxioURI, UfsStatus) - Method in class alluxio.underfs.UfsStatusCache
Add a new status to the cache.
addStorage(String) - Method in class alluxio.grpc.StorageList.Builder
a lost storage path
addStorageBytes(ByteString) - Method in class alluxio.grpc.StorageList.Builder
a lost storage path
addStorageTiers(String) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the list of storage tiers
addStorageTiersBytes(ByteString) - Method in class alluxio.grpc.RegisterWorkerPRequest.Builder
the list of storage tiers
addSummaryPerStatus(StatusSummary) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
addSummaryPerStatus(int, StatusSummary) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
addSummaryPerStatus(StatusSummary.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
addSummaryPerStatus(int, StatusSummary.Builder) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
addSummaryPerStatusBuilder() - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
addSummaryPerStatusBuilder(int) - Method in class alluxio.grpc.JobServiceSummary.Builder
repeated .alluxio.grpc.job.StatusSummary summaryPerStatus = 1;
addTable(String) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
repeated string table = 1;
addTableBytes(ByteString) - Method in class alluxio.grpc.table.GetAllTablesPResponse.Builder
repeated string table = 1;
addTablesIgnored(String) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_ignored = 2;
addTablesIgnoredBytes(ByteString) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_ignored = 2;
addTablesRemoved(String) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_removed = 5;
addTablesRemovedBytes(ByteString) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_removed = 5;
addTablesUnchanged(String) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_unchanged = 3;
addTablesUnchangedBytes(ByteString) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_unchanged = 3;
addTablesUpdated(String) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_updated = 4;
addTablesUpdatedBytes(ByteString) - Method in class alluxio.grpc.table.SyncStatus.Builder
repeated string tables_updated = 4;
addTag(String, String) - Method in class alluxio.metrics.Metric
Adds a new tag.
addTags(Map<String, String>) - Method in class alluxio.s3.TaggingData
Merges the contents of the provided tag map with the existing tags.
addTask(long, WorkerInfo, Object) - Method in class alluxio.job.plan.meta.PlanInfo
Registers a task.
addTaskInfos(JobInfo) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
addTaskInfos(int, JobInfo) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
addTaskInfos(JobInfo.Builder) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
addTaskInfos(int, JobInfo.Builder) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
addTaskInfosBuilder() - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
addTaskInfosBuilder(int) - Method in class alluxio.grpc.JobHeartbeatPRequest.Builder
repeated .alluxio.grpc.job.JobInfo taskInfos = 2;
addTempBlockMeta(TempBlockMeta) - Method in interface alluxio.worker.block.meta.StorageDir
Adds the metadata of a new block into this storage dir.
addTempPage(PageId, PageInfo) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
addTempPage(PageId, PageInfo) - Method in interface alluxio.client.file.cache.PageMetaStore
Adds a new temp page to the cache.
addThreadCountResults(int, ClientIOTaskResult.ThreadCountResult) - Method in class alluxio.stress.client.ClientIOTaskResult
 
addThreads(String) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
repeated string threads = 1;
addThreadsBytes(ByteString) - Method in class alluxio.grpc.GetStateLockHoldersPResponse.Builder
repeated string threads = 1;
addTiers(long) - Method in class alluxio.grpc.TierList.Builder
repeated int64 tiers = 1;
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.
addToRetry(Route) - Method in class alluxio.master.job.CopyJob
Add a route to retry later.
addToRetry(Route) - Method in class alluxio.master.job.MoveJob
Add a route to retry later.
addTransformations(Transformation) - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
addTransformations(int, Transformation) - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
addTransformations(Transformation.Builder) - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
addTransformations(int, Transformation.Builder) - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
addTransformationsBuilder() - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
addTransformationsBuilder(int) - Method in class alluxio.grpc.table.Partition.Builder
The latest transformation is in the back of the list.
addUfsLocations(WorkerNetAddress) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
addUfsLocations(int, WorkerNetAddress) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
addUfsLocations(WorkerNetAddress.Builder) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
addUfsLocations(int, WorkerNetAddress.Builder) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
addUfsLocationsBuilder() - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
addUfsLocationsBuilder(int) - Method in class alluxio.grpc.FileBlockInfo.Builder
deprecated since 1.1 will be removed in 2.0 (replaced by ufsStringLocations)
addUfsStatus(UfsStatus) - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
addUfsStatus(int, UfsStatus) - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
addUfsStatus(UfsStatus.Builder) - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
addUfsStatus(int, UfsStatus.Builder) - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
addUfsStatusBuilder() - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
addUfsStatusBuilder(int) - Method in class alluxio.grpc.LoadFileRequest.Builder
repeated .alluxio.grpc.block.UfsStatus ufs_status = 1;
addUfsStringLocations(String) - Method in class alluxio.grpc.FileBlockInfo.Builder
repeated string ufsStringLocations = 4;
addUfsStringLocationsBytes(ByteString) - Method in class alluxio.grpc.FileBlockInfo.Builder
repeated string ufsStringLocations = 4;
addUnused0(JobUnused) - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
addUnused0(int, JobUnused) - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
addUnused0(JobUnused.Builder) - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
addUnused0(int, JobUnused.Builder) - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
addUnused0Builder() - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
addUnused0Builder(int) - Method in class alluxio.grpc.JobInfo.Builder
Around for backwards compatibility
addUserActions(Acl.NamedAclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
addUserActions(int, Acl.NamedAclActions) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
addUserActions(Acl.NamedAclActions.Builder) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
addUserActions(int, Acl.NamedAclActions.Builder) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
addUserActionsBuilder() - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
addUserActionsBuilder(int) - Method in class alluxio.proto.shared.Acl.AccessControlList.Builder
repeated .alluxio.proto.shared.NamedAclActions userActions = 3;
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.
addValidated(Supplier<JournalContext>, AlluxioURI, AlluxioURI, long, MountPOptions) - Method in class alluxio.master.file.meta.MountTable
Inserts an entry into the mount table.
addValue(double) - Method in class alluxio.metrics.Metric
Add metric value delta to the existing value.
addValues(String) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
repeated string values = 1;
addValues(String) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
list of string values for each partition column
addValuesBytes(ByteString) - Method in class alluxio.grpc.InconsistentPropertyValues.Builder
repeated string values = 1;
addValuesBytes(ByteString) - Method in class alluxio.grpc.table.layout.hive.PartitionInfo.Builder
list of string values for each partition column
addWorkerAddresses(NetAddress) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
addWorkerAddresses(int, NetAddress) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
addWorkerAddresses(NetAddress.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
addWorkerAddresses(int, NetAddress.Builder) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
addWorkerAddressesBuilder() - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
addWorkerAddressesBuilder(int) - Method in class alluxio.grpc.MasterInfo.Builder
repeated .alluxio.grpc.NetAddress workerAddresses = 9;
addWorkerHealths(JobWorkerHealth) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
addWorkerHealths(int, JobWorkerHealth) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
addWorkerHealths(JobWorkerHealth.Builder) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
addWorkerHealths(int, JobWorkerHealth.Builder) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
addWorkerHealthsBuilder() - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
addWorkerHealthsBuilder(int) - Method in class alluxio.grpc.GetAllWorkerHealthPResponse.Builder
repeated .alluxio.grpc.job.JobWorkerHealth workerHealths = 1;
addWorkerInfos(WorkerInfo) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
addWorkerInfos(int, WorkerInfo) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
addWorkerInfos(WorkerInfo.Builder) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
addWorkerInfos(int, WorkerInfo.Builder) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
addWorkerInfosBuilder() - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
addWorkerInfosBuilder(int) - Method in class alluxio.grpc.GetWorkerInfoListPResponse.Builder
repeated .alluxio.grpc.block.WorkerInfo workerInfos = 1;
addWorkerLostStorageInfo(WorkerLostStorageInfo) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
addWorkerLostStorageInfo(int, WorkerLostStorageInfo) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
addWorkerLostStorageInfo(WorkerLostStorageInfo.Builder) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
addWorkerLostStorageInfo(int, WorkerLostStorageInfo.Builder) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
addWorkerLostStorageInfoBuilder() - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
addWorkerLostStorageInfoBuilder(int) - Method in class alluxio.grpc.GetWorkerLostStoragePResponse.Builder
repeated .alluxio.grpc.block.WorkerLostStorageInfo workerLostStorageInfo = 1;
addZookeeperAddresses(String) - Method in class alluxio.grpc.MasterInfo.Builder
Empty means zookeeper is not enabled
addZookeeperAddressesBytes(ByteString) - Method in class alluxio.grpc.MasterInfo.Builder
Empty means zookeeper is not enabled
AdlUnderFileSystem - Class in alluxio.underfs.adl
A Microsoft Azure Data Lake Storage Gen 1 Implementation.
AdlUnderFileSystem(AlluxioURI, UnderFileSystemConfiguration, Configuration) - Constructor for class alluxio.underfs.adl.AdlUnderFileSystem
Constructs a new Adl UnderFileSystem.
AdlUnderFileSystemFactory - Class in alluxio.underfs.adl
Factory for creating AdlUnderFileSystem.
AdlUnderFileSystemFactory() - Constructor for class alluxio.underfs.adl.AdlUnderFileSystemFactory
Constructs a new AdlUnderFileSystemFactory.
advance() - Method in interface alluxio.master.journal.JournalReader
Advances the reader to the next element.
advance() - Method in class alluxio.master.journal.ufs.UfsJournalReader
 
affectedPaths() - Method in class alluxio.job.cmd.migrate.MigrateCliConfig
 
affectedPaths() - Method in class alluxio.job.cmd.persist.PersistCmdConfig
 
affectedPaths() - Method in interface alluxio.job.CmdConfig
 
affectedPaths() - Method in interface alluxio.job.JobConfig
 
affectedPaths() - Method in class alluxio.job.plan.BatchedJobConfig
 
affectedPaths() - Method in class alluxio.job.plan.migrate.MigrateConfig
 
affectedPaths() - Method in class alluxio.job.plan.NoopPlanConfig
 
affectedPaths() - Method in class alluxio.job.plan.persist.PersistConfig
 
affectedPaths() - Method in class alluxio.job.plan.replicate.MoveConfig
 
affectedPaths() - Method in class alluxio.job.workflow.composite.CompositeConfig
 
affectedPaths() - Method in class alluxio.stress.job.StressBenchConfig
 
AFFECTEDPATHS_FIELD_NUMBER - Static variable in class alluxio.grpc.JobInfo
 
AffinityHashAllocator - Class in alluxio.client.file.cache.allocator
Offers stickiness allocation based on the file id.
AffinityHashAllocator(List<PageStoreDir>) - Constructor for class alluxio.client.file.cache.allocator.AffinityHashAllocator
 
AffinityHashAllocator(List<PageStoreDir>, Function<String, Integer>) - Constructor for class alluxio.client.file.cache.allocator.AffinityHashAllocator
 
after() - Method in class alluxio.dora.meta.DoraMetaBench.Db
 
after() - Method in class alluxio.inode.InodeBenchRead.Db
 
after() - Method in class alluxio.inode.InodeBenchWrite.Db
 
after() - Method in class alluxio.inode.InodeBenchWrite.ThreadState
 
after() - Method in class alluxio.inode.RocksBenchRead.Db
 
after() - Method in class alluxio.inode.RocksBenchReadWrite.Db
 
after() - Method in class alluxio.inode.RocksBenchReadWrite.ThreadState
 
after() - Method in class alluxio.inode.RocksBenchWrite.Db
 
after() - Method in class alluxio.inode.RocksBenchWrite.ThreadState
 
after(long) - Static method in class alluxio.master.predicate.interval.Interval
 
afterConnect() - Method in class alluxio.AbstractClient
This method is called after the connection is made to the remote.
afterConnect() - Method in class alluxio.client.block.RetryHandlingBlockMasterClient
 
afterConnect() - Method in class alluxio.client.file.RetryHandlingFileSystemMasterClient
 
afterConnect() - Method in class alluxio.client.job.RetryHandlingJobMasterClient
 
afterConnect() - Method in class alluxio.client.journal.RetryHandlingJournalMasterClient
 
afterConnect() - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
 
afterConnect() - Method in class alluxio.client.meta.RetryHandlingMetaMasterConfigClient
 
afterConnect() - Method in class alluxio.client.metrics.RetryHandlingMetricsMasterClient
 
afterConnect() - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
afterConnect() - Method in class alluxio.master.file.FileSystemMasterClient
 
afterConnect() - Method in class alluxio.master.journal.raft.RaftJournalServiceClient
 
afterConnect() - Method in class alluxio.master.meta.RetryHandlingJobMasterMasterClient
 
afterConnect() - Method in class alluxio.master.meta.RetryHandlingMetaMasterMasterClient
 
afterConnect() - Method in class alluxio.proxy.RetryHandlingMetaMasterProxyClient
 
afterConnect() - Method in class alluxio.worker.block.BlockMasterClient
 
afterConnect() - Method in class alluxio.worker.file.FileSystemMasterClient
 
afterConnect() - Method in class alluxio.worker.job.RetryHandlingJobMasterClient
 
afterDisconnect() - Method in class alluxio.AbstractClient
This method is called after the connection is disconnected.
afterDisconnect() - Method in class alluxio.AbstractMasterClient
 
AGENT_OUTPUT_PATH - Static variable in class alluxio.stress.BaseParameters
 
aggregate(Iterable<T>) - Method in interface alluxio.stress.TaskResult.Aggregator
Aggregates multiple instances of a TaskResult to a summary.
aggregateByWorker(WorkerBenchTaskResult) - Method in class alluxio.stress.worker.WorkerBenchTaskResult
Merges (updates) a task result with this result except the error information.
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.
aggregator() - Method in class alluxio.stress.client.ClientIOTaskResult
 
aggregator() - Method in interface alluxio.stress.TaskResult
 
aggregator() - Method in class alluxio.stress.worker.IOTaskResult
 
aggregator() - Method in class alluxio.stress.worker.WorkerBenchTaskResult
 
aging() - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
Decrease each item's clock and clean stale items.
aging() - Method in class alluxio.client.file.cache.ClockCuckooShadowCacheManager
 
aging() - Method in interface alluxio.client.file.cache.cuckoofilter.ClockCuckooFilter
A thread-safe method to check aging progress of each segment.
aging() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
aging() - Method in class alluxio.client.file.cache.MultipleBloomShadowCacheManager
 
aging() - Method in interface alluxio.client.file.cache.ShadowCacheManager
Aging all the pages stored in this shadow cache.
ALL - Static variable in enum alluxio.client.block.options.GetWorkerReportOptions.WorkerInfoField
 
ALL_FACTORIES - Static variable in interface alluxio.master.predicate.FilePredicate
 
ALL_FIELD_NUMBER - Static variable in class alluxio.grpc.table.AllOrNoneSet
 
ALL_OR_NONE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Domain
 
ALL_VALUE - Static variable in enum alluxio.grpc.Bits
ALL = 8;
ALL_VALUE - Static variable in enum alluxio.grpc.LoadDescendantPType
ALL = 2;
ALL_VALUE - Static variable in enum alluxio.grpc.Scope
ALL = 7;
ALL_VALUE - Static variable in enum alluxio.grpc.WorkerRange
ALL = 1;
allEdges() - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
allEdges() - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
allEdges() - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
allEdges() - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
allEdges() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
allInodes() - Method in class alluxio.master.metastore.caching.CachingInodeStore
 
allInodes() - Method in class alluxio.master.metastore.DelegatingReadOnlyInodeStore
 
allInodes() - Method in class alluxio.master.metastore.heap.HeapInodeStore
 
allInodes() - Method in interface alluxio.master.metastore.ReadOnlyInodeStore
 
allInodes() - Method in class alluxio.master.metastore.rocks.RocksInodeStore
 
AllMastersWorkerInfo - Class in alluxio.client.block
A data class to persist aggregated worker info from all masters, including standby masters.
AllMastersWorkerInfo(Map<Long, InetSocketAddress>, List<InetSocketAddress>, InetSocketAddress, List<WorkerInfo>, Map<Long, List<Pair<InetSocketAddress, WorkerInfo>>>) - Constructor for class alluxio.client.block.AllMastersWorkerInfo
 
allMetricKeys() - Static method in class alluxio.metrics.MetricKey
 
allMetrics() - Static method in class alluxio.metrics.MetricsSystem
 
allocate(String, long) - Method in class alluxio.client.file.cache.allocator.AffinityHashAllocator
 
allocate(String, long) - Method in interface alluxio.client.file.cache.allocator.Allocator
 
allocate(String, long) - Method in class alluxio.client.file.cache.allocator.HashAllocator
 
allocate(String, long) - Method in class alluxio.client.file.cache.DefaultPageMetaStore
 
allocate(String, long) - Method in interface alluxio.client.file.cache.PageMetaStore
 
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.
Allocator - Interface in alluxio.client.file.cache.allocator
Local cache allocator.
allOf(CompletableFuture<?>...) - Static method in class alluxio.concurrent.jsr.CompletableFuture
Returns a new CompletableFuture that is completed when all of the given CompletableFutures complete.
allOf(List<CatchupFuture>) - Static method in class alluxio.master.journal.CatchupFuture
Creates a single future for tracking a list of catchup futures.
AllOrNoneSet - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.AllOrNoneSet
AllOrNoneSet.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.AllOrNoneSet
AllOrNoneSetOrBuilder - Interface in alluxio.grpc.table
 
allow() - Method in class alluxio.client.file.FileSystemContextReinitializer
Acquires the resource to allow reinitialization.
ALLOWED_FIELD_NUMBER - Static variable in class alluxio.grpc.GetRegisterLeasePResponse
 
ALLOWEDONSTANDBYMASTERS_FIELD_NUMBER - Static variable in class alluxio.grpc.GetServiceVersionPRequest
 
ALLOWEXISTS_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateDirectoryPOptions
 
ALLOWLEADER_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPOptions
 
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.annotation - package alluxio.annotation
 
alluxio.annotation.dora - package alluxio.annotation.dora
 
alluxio.check - package alluxio.check
 
alluxio.cli - package alluxio.cli
 
alluxio.cli.bundler - package alluxio.cli.bundler
 
alluxio.cli.bundler.command - package alluxio.cli.bundler.command
 
alluxio.cli.command - package alluxio.cli.command
 
alluxio.cli.command.metadatacache - package alluxio.cli.command.metadatacache
 
alluxio.cli.docgen - package alluxio.cli.docgen
 
alluxio.cli.extensions - package alluxio.cli.extensions
 
alluxio.cli.extensions.command - package alluxio.cli.extensions.command
 
alluxio.cli.fs - package alluxio.cli.fs
 
alluxio.cli.fs.command - package alluxio.cli.fs.command
 
alluxio.cli.fs.command.job - package alluxio.cli.fs.command.job
 
alluxio.cli.fsadmin - package alluxio.cli.fsadmin
 
alluxio.cli.fsadmin.command - package alluxio.cli.fsadmin.command
 
alluxio.cli.fsadmin.doctor - package alluxio.cli.fsadmin.doctor
 
alluxio.cli.fsadmin.journal - package alluxio.cli.fsadmin.journal
 
alluxio.cli.fsadmin.metrics - package alluxio.cli.fsadmin.metrics
 
alluxio.cli.fsadmin.nodes - package alluxio.cli.fsadmin.nodes
 
alluxio.cli.fsadmin.report - package alluxio.cli.fsadmin.report
 
alluxio.cli.hdfs - package alluxio.cli.hdfs
 
alluxio.cli.hms - package alluxio.cli.hms
 
alluxio.cli.util - package alluxio.cli.util
 
alluxio.client - package alluxio.client
 
alluxio.client.block - package alluxio.client.block
 
alluxio.client.block.options - package alluxio.client.block.options
 
alluxio.client.block.stream - package alluxio.client.block.stream
 
alluxio.client.block.util - package alluxio.client.block.util
 
alluxio.client.file - package alluxio.client.file
 
alluxio.client.file.cache - package alluxio.client.file.cache
 
alluxio.client.file.cache.allocator - package alluxio.client.file.cache.allocator
 
alluxio.client.file.cache.context - package alluxio.client.file.cache.context
 
alluxio.client.file.cache.cuckoofilter - package alluxio.client.file.cache.cuckoofilter
 
alluxio.client.file.cache.evictor - package alluxio.client.file.cache.evictor
 
alluxio.client.file.cache.filter - package alluxio.client.file.cache.filter
 
alluxio.client.file.cache.store - package alluxio.client.file.cache.store
 
alluxio.client.file.dora - package alluxio.client.file.dora
 
alluxio.client.file.dora.netty - package alluxio.client.file.dora.netty
 
alluxio.client.file.dora.netty.event - package alluxio.client.file.dora.netty.event
 
alluxio.client.file.options - package alluxio.client.file.options
 
alluxio.client.file.ufs - package alluxio.client.file.ufs
 
alluxio.client.hive - package alluxio.client.hive
 
alluxio.client.job - package alluxio.client.job
 
alluxio.client.journal - package alluxio.client.journal
 
alluxio.client.meta - package alluxio.client.meta
 
alluxio.client.metrics - package alluxio.client.metrics
 
alluxio.client.quota - package alluxio.client.quota
 
alluxio.client.table - package alluxio.client.table
 
alluxio.clock - package alluxio.clock
 
alluxio.collections - package alluxio.collections
 
alluxio.common - package alluxio.common
 
alluxio.concurrent - package alluxio.concurrent
 
alluxio.concurrent.jsr - package alluxio.concurrent.jsr
 
alluxio.conf - package alluxio.conf
 
alluxio.conf.reference - package alluxio.conf.reference
 
alluxio.dora.meta - package alluxio.dora.meta
 
alluxio.examples - package alluxio.examples
 
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.fsmaster - package alluxio.fsmaster
 
alluxio.fuse - package alluxio.fuse
 
alluxio.fuse.auth - package alluxio.fuse.auth
 
alluxio.fuse.file - package alluxio.fuse.file
 
alluxio.fuse.lock - package alluxio.fuse.lock
 
alluxio.fuse.meta - package alluxio.fuse.meta
 
alluxio.fuse.options - package alluxio.fuse.options
 
alluxio.grpc - package alluxio.grpc
 
alluxio.grpc.table - package alluxio.grpc.table
 
alluxio.grpc.table.layout.hive - package alluxio.grpc.table.layout.hive
 
alluxio.hadoop - package alluxio.hadoop
 
alluxio.heartbeat - package alluxio.heartbeat
 
alluxio.inode - package alluxio.inode
 
alluxio.invalidation.cache - package alluxio.invalidation.cache
 
alluxio.jnifuse - package alluxio.jnifuse
 
alluxio.jnifuse.constants - package alluxio.jnifuse.constants
 
alluxio.jnifuse.struct - package alluxio.jnifuse.struct
 
alluxio.jnifuse.utils - package alluxio.jnifuse.utils
 
alluxio.job - package alluxio.job
 
alluxio.job.cmd - package alluxio.job.cmd
 
alluxio.job.cmd.migrate - package alluxio.job.cmd.migrate
 
alluxio.job.cmd.persist - package alluxio.job.cmd.persist
 
alluxio.job.cmd.replicate - package alluxio.job.cmd.replicate
 
alluxio.job.meta - package alluxio.job.meta
 
alluxio.job.plan - package alluxio.job.plan
 
alluxio.job.plan.batch - package alluxio.job.plan.batch
 
alluxio.job.plan.meta - package alluxio.job.plan.meta
 
alluxio.job.plan.migrate - package alluxio.job.plan.migrate
 
alluxio.job.plan.persist - package alluxio.job.plan.persist
 
alluxio.job.plan.replicate - package alluxio.job.plan.replicate
 
alluxio.job.plan.stress - package alluxio.job.plan.stress
 
alluxio.job.util - package alluxio.job.util
 
alluxio.job.wire - package alluxio.job.wire
 
alluxio.job.workflow - package alluxio.job.workflow
 
alluxio.job.workflow.composite - package alluxio.job.workflow.composite
 
alluxio.master - package alluxio.master
 
alluxio.master.audit - package alluxio.master.audit
 
alluxio.master.backcompat - package alluxio.master.backcompat
 
alluxio.master.backcompat.ops - package alluxio.master.backcompat.ops
 
alluxio.master.backup - package alluxio.master.backup
 
alluxio.master.block - package alluxio.master.block
 
alluxio.master.block.meta - package alluxio.master.block.meta
 
alluxio.master.file - package alluxio.master.file
 
alluxio.master.file.async - package alluxio.master.file.async
 
alluxio.master.file.contexts - package alluxio.master.file.contexts
 
alluxio.master.file.meta - package alluxio.master.file.meta
 
alluxio.master.file.meta.options - package alluxio.master.file.meta.options
 
alluxio.master.file.meta.xattr - package alluxio.master.file.meta.xattr
 
alluxio.master.file.state - package alluxio.master.file.state
 
alluxio.master.job - package alluxio.master.job
 
alluxio.master.job.command - package alluxio.master.job.command
 
alluxio.master.job.common - package alluxio.master.job.common
 
alluxio.master.job.metrics - package alluxio.master.job.metrics
 
alluxio.master.job.plan - package alluxio.master.job.plan
 
alluxio.master.job.tracker - package alluxio.master.job.tracker
 
alluxio.master.job.workflow - package alluxio.master.job.workflow
 
alluxio.master.journal - package alluxio.master.journal
 
alluxio.master.journal.checkpoint - package alluxio.master.journal.checkpoint
 
alluxio.master.journal.noop - package alluxio.master.journal.noop
 
alluxio.master.journal.options - package alluxio.master.journal.options
 
alluxio.master.journal.raft - package alluxio.master.journal.raft
 
alluxio.master.journal.sink - package alluxio.master.journal.sink
 
alluxio.master.journal.tool - package alluxio.master.journal.tool
 
alluxio.master.journal.ufs - package alluxio.master.journal.ufs
 
alluxio.master.journalv0 - package alluxio.master.journalv0
 
alluxio.master.journalv0.ufs - package alluxio.master.journalv0.ufs
 
alluxio.master.meta - package alluxio.master.meta
 
alluxio.master.meta.checkconf - package alluxio.master.meta.checkconf
 
alluxio.master.metastore - package alluxio.master.metastore
 
alluxio.master.metastore.caching - package alluxio.master.metastore.caching
 
alluxio.master.metastore.heap - package alluxio.master.metastore.heap
 
alluxio.master.metastore.rocks - package alluxio.master.metastore.rocks
 
alluxio.master.metrics - package alluxio.master.metrics
 
alluxio.master.predicate - package alluxio.master.predicate
 
alluxio.master.predicate.interval - package alluxio.master.predicate.interval
 
alluxio.master.scheduler - package alluxio.master.scheduler
 
alluxio.master.selectionpolicy - package alluxio.master.selectionpolicy
 
alluxio.master.service - package alluxio.master.service
 
alluxio.master.service.jvmmonitor - package alluxio.master.service.jvmmonitor
 
alluxio.master.service.metrics - package alluxio.master.service.metrics
 
alluxio.master.service.rpc - package alluxio.master.service.rpc
 
alluxio.master.service.web - package alluxio.master.service.web
 
alluxio.master.transport - package alluxio.master.transport
 
alluxio.membership - package alluxio.membership
 
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.multi.process - package alluxio.multi.process
 
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.proto.client - package alluxio.proto.client
 
alluxio.proto.dataserver - package alluxio.proto.dataserver
 
alluxio.proto.journal - package alluxio.proto.journal
 
alluxio.proto.meta - package alluxio.proto.meta
 
alluxio.proto.shared - package alluxio.proto.shared
 
alluxio.proto.status - package alluxio.proto.status
 
alluxio.proxy - package alluxio.proxy
 
alluxio.proxy.s3 - package alluxio.proxy.s3
 
alluxio.proxy.s3.logging - package alluxio.proxy.s3.logging
 
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.rocks - package alluxio.rocks
 
alluxio.s3 - package alluxio.s3
 
alluxio.s3.auth - package alluxio.s3.auth
 
alluxio.s3.signature - package alluxio.s3.signature
 
alluxio.s3.signature.utils - package alluxio.s3.signature.utils
 
alluxio.scheduler.job - package alluxio.scheduler.job
 
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.snapshot - package alluxio.snapshot
 
alluxio.stress - package alluxio.stress
 
alluxio.stress.cli - package alluxio.stress.cli
 
alluxio.stress.cli.client - package alluxio.stress.cli.client
 
alluxio.stress.cli.report - package alluxio.stress.cli.report
 
alluxio.stress.cli.worker - package alluxio.stress.cli.worker
 
alluxio.stress.client - package alluxio.stress.client
 
alluxio.stress.common - package alluxio.stress.common
 
alluxio.stress.graph - package alluxio.stress.graph
 
alluxio.stress.job - package alluxio.stress.job
 
alluxio.stress.worker - package alluxio.stress.worker
 
alluxio.table - package alluxio.table
 
alluxio.thread - package alluxio.thread
 
alluxio.time - package alluxio.time
 
alluxio.underfs - package alluxio.underfs
 
alluxio.underfs.abfs - package alluxio.underfs.abfs
 
alluxio.underfs.adl - package alluxio.underfs.adl
 
alluxio.underfs.cephfs - package alluxio.underfs.cephfs
 
alluxio.underfs.cephfshadoop - package alluxio.underfs.cephfshadoop
 
alluxio.underfs.cos - package alluxio.underfs.cos
 
alluxio.underfs.cosn - package alluxio.underfs.cosn
 
alluxio.underfs.gcs - package alluxio.underfs.gcs
 
alluxio.underfs.gcs.v2 - package alluxio.underfs.gcs.v2
 
alluxio.underfs.hdfs - package alluxio.underfs.hdfs
 
alluxio.underfs.hdfs.acl - package alluxio.underfs.hdfs.acl
 
alluxio.underfs.local - package alluxio.underfs.local
 
alluxio.underfs.obs - package alluxio.underfs.obs
 
alluxio.underfs.options - package alluxio.underfs.options
 
alluxio.underfs.oss - package alluxio.underfs.oss
 
alluxio.underfs.ozone - package alluxio.underfs.ozone
 
alluxio.underfs.s3a - package alluxio.underfs.s3a
 
alluxio.underfs.wasb - package alluxio.underfs.wasb
 
alluxio.uri - package alluxio.uri
 
alluxio.util - package alluxio.util
 
alluxio.util.compression - package alluxio.util.compression
 
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.web - package alluxio.web
 
alluxio.wire - package alluxio.wire
 
alluxio.worker - package alluxio.worker
Worker process and utils for working with the worker remotely.
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
 
alluxio.worker.file - package alluxio.worker.file
 
alluxio.worker.grpc - package alluxio.worker.grpc
 
alluxio.worker.http - package alluxio.worker.http
 
alluxio.worker.job - package alluxio.worker.job
 
alluxio.worker.job.command - package alluxio.worker.job.command
 
alluxio.worker.job.task - package alluxio.worker.job.task
 
alluxio.worker.modules - package alluxio.worker.modules
 
alluxio.worker.netty - package alluxio.worker.netty
 
alluxio.worker.s3 - package alluxio.worker.s3
 
alluxio.worker.task - package alluxio.worker.task
 
ALLUXIO_2X_UPGRADE_DOC_URL - Static variable in class alluxio.RuntimeConstants
The URL of Alluxio 1.x to 2.x upgrade documentation.
ALLUXIO_BLOCK_VALUE - Static variable in enum alluxio.grpc.RequestType
ALLUXIO_BLOCK = 0;
ALLUXIO_BLOCK_VALUE - Static variable in enum alluxio.proto.dataserver.Protocol.RequestType
ALLUXIO_BLOCK = 0;
ALLUXIO_CLI_PATH - Static variable in class alluxio.Constants
 
ALLUXIO_CLUSTER_NAME - Static variable in class alluxio.conf.PropertyKey
 
ALLUXIO_CLUSTER_NAME - Static variable in class alluxio.conf.PropertyKey.Name
 
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_FILESYSTEM_CLIENT_RESOURCE_KEY - Static variable in class alluxio.web.MasterWebServer
 
ALLUXIO_FILESYSTEM_CLIENT_RESOURCE_KEY - Static variable in class alluxio.web.WorkerWebServer
 
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_JOB_MASTER_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.JobMasterWebServer
 
ALLUXIO_JOB_WORKER_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.JobWorkerWebServer
 
ALLUXIO_MASTER_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.MasterWebServer
 
ALLUXIO_PATH_FIELD_NUMBER - Static variable in class alluxio.grpc.File
 
ALLUXIO_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.AddMountPointEntry
 
ALLUXIO_PATH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.DeleteMountPointEntry
 
ALLUXIO_PROXY_AUDIT_LOG_WRITER_KEY - Static variable in class alluxio.web.ProxyWebServer
 
ALLUXIO_PROXY_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.ProxyWebServer
 
ALLUXIO_SECURITY_DOCS_URL - Static variable in class alluxio.RuntimeConstants
The URL of Alluxio security documentation.
ALLUXIO_USER_HEADER - Static variable in class alluxio.proxy.s3.S3RestUtils
 
ALLUXIO_WORKER_SERVLET_RESOURCE_KEY - Static variable in class alluxio.web.WorkerWebServer
 
AlluxioBenchThreadState() - Constructor for class alluxio.fsmaster.FileSystemBench.AlluxioBenchThreadState
 
AlluxioCommand(String, String) - Constructor for class alluxio.cli.bundler.command.CollectAlluxioInfoCommand.AlluxioCommand
AlluxioConfiguration - Interface in alluxio.conf
Alluxio configuration.
AlluxioEtcdClient - Class in alluxio.membership
Wrapper class around jetcd client to achieve utilities API to talk with ETCD.
AlluxioEtcdClient(AlluxioConfiguration) - Constructor for class alluxio.membership.AlluxioEtcdClient
CTOR for AlluxioEtcdClient.
AlluxioEtcdClient.EtcdUtilCallable<V> - Interface in alluxio.membership
 
AlluxioEtcdClient.Lease - Class in alluxio.membership
Lease structure to keep the info about a lease in etcd.
AlluxioException - Exception in alluxio.exception
General AlluxioException used throughout the system.
AlluxioException(Throwable) - Constructor for exception alluxio.exception.AlluxioException
Constructs an AlluxioException with the given cause.
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.
AlluxioExecutorService - Class in alluxio.master
Forwarder over ExecutorService interface for exposing internal queue length.
AlluxioExecutorService(ExecutorService) - Constructor for class alluxio.master.AlluxioExecutorService
Creates Alluxio ExecutorService wrapper.
AlluxioExecutorService(ExecutorService, Counter) - Constructor for class alluxio.master.AlluxioExecutorService
Creates Alluxio ExecutorService wrapper.
AlluxioFileStatus - Class in alluxio.hadoop
A enhanced file status class that additional stores the uri status, including the block location info so that we don't need to make an additional RPC call to fetch the block location from the hadoop client.
AlluxioFileStatus(URIStatus, Path) - Constructor for class alluxio.hadoop.AlluxioFileStatus
Constructs a new AlluxioFileStatus instance.
AlluxioFileSystem - Class in alluxio.hadoop
The Alluxio implementation of Hadoop AbstractFileSystem.
AlluxioForkJoinWorkerThreadFactory(String, boolean) - Constructor for class alluxio.concurrent.jsr.ForkJoinPool.AlluxioForkJoinWorkerThreadFactory
Creates a new thread-factory for ForkJoinPool.
AlluxioFS - Class in alluxio.examples
Example program to use Alluxio native API to read and write files.
AlluxioFS() - Constructor for class alluxio.examples.AlluxioFS
 
AlluxioFuse - Class in alluxio.fuse
Main entry point to Alluxio-FUSE.
AlluxioFuse() - Constructor for class alluxio.fuse.AlluxioFuse
 
AlluxioFuseOpenUtils - Class in alluxio.fuse
Alluxio Fuse utilities to handle different fuse.open() flags.
AlluxioFuseOpenUtils() - Constructor for class alluxio.fuse.AlluxioFuseOpenUtils
 
AlluxioFuseOpenUtils.OpenAction - Enum in alluxio.fuse
Alluxio Fuse open action.
AlluxioFuseUtils - Class in alluxio.fuse
Utility methods for Alluxio-FUSE.
AlluxioFuseUtils.CloseableFuseFileInfo - Class in alluxio.fuse
Creates a closeable fuse file info.
AlluxioFuseUtils.FuseCallable - Interface in alluxio.fuse
An interface representing a callable for FUSE APIs.
alluxioGetStatusBench(Blackhole, FileSystemBench.AlluxioBenchThreadState) - Method in class alluxio.fsmaster.FileSystemBench
 
AlluxioHDFS - Class in alluxio.examples
Example program to use Alluxio Hadoop Compatible API to read and write files.
AlluxioHDFS() - Constructor for class alluxio.examples.AlluxioHDFS
 
AlluxioHdfsException - Exception in alluxio.underfs.hdfs
Alluxio exception for HDFS.
AlluxioHdfsInputStream - Class in alluxio.hadoop
A wrapper class to translate Hadoop FileSystem FSDataInputStream to Alluxio FileSystem FileInStream.
AlluxioHdfsInputStream(FSDataInputStream) - Constructor for class alluxio.hadoop.AlluxioHdfsInputStream
 
AlluxioHdfsPositionReader - Class in alluxio.hadoop
A wrapper class to translate Hadoop FileSystem FSDataInputStream to Alluxio FileSystem PositionReader.
AlluxioHdfsPositionReader(FSDataInputStream, long) - Constructor for class alluxio.hadoop.AlluxioHdfsPositionReader
 
AlluxioJniFuseFileSystem - Class in alluxio.fuse
Main FUSE implementation class.
AlluxioJniFuseFileSystem(FileSystemContext, FileSystem, FuseOptions) - Constructor for class alluxio.fuse.AlluxioJniFuseFileSystem
Creates a new instance of AlluxioJniFuseFileSystem.
AlluxioJniRenameUtils - Class in alluxio.fuse
Alluxio Fuse utilities to handle different fuse.rename() flags.
AlluxioJniRenameUtils() - Constructor for class alluxio.fuse.AlluxioJniRenameUtils
 
AlluxioJobMaster - Class in alluxio.master
Entry point for the Alluxio job master program.
AlluxioJobMasterInfo - Class in alluxio.wire
Alluxio job master information.
AlluxioJobMasterInfo() - Constructor for class alluxio.wire.AlluxioJobMasterInfo
Creates a new instance of AlluxioJobMasterInfo.
AlluxioJobMasterMonitor - Class in alluxio.master.job
Alluxio job_master monitor for inquiring AlluxioJobMaster service availability.
AlluxioJobMasterProcess - Class in alluxio.master
This class is responsible for initializing the different masters that are configured to run.
AlluxioJobMasterRestServiceHandler - Class in alluxio.master
This class is a REST handler for requesting general job master information.
AlluxioJobMasterRestServiceHandler(ServletContext) - Constructor for class alluxio.master.AlluxioJobMasterRestServiceHandler
 
AlluxioJobWorker - Class in alluxio.worker
Entry point for the Alluxio worker.
AlluxioJobWorkerInfo - Class in alluxio.wire
Alluxio job worker information.
AlluxioJobWorkerInfo() - Constructor for class alluxio.wire.AlluxioJobWorkerInfo
Creates a new instance of AlluxioJobWorkerInfo.
AlluxioJobWorkerMonitor - Class in alluxio.worker.job
Alluxio job_worker monitor for inquiring AlluxioJobWorkerMonitor service availability.
AlluxioJobWorkerProcess - Class in alluxio.worker
This class is responsible for initializing the different workers that are configured to run.
AlluxioJobWorkerRestServiceHandler - Class in alluxio.worker
This class is a REST handler for requesting general job worker information.
AlluxioJobWorkerRestServiceHandler(ServletContext) - Constructor for class alluxio.worker.AlluxioJobWorkerRestServiceHandler
 
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.
AlluxioMaster - Class in alluxio.master
Entry point for the Alluxio master.
AlluxioMasterInfo - Class in alluxio.wire
Alluxio master information.
AlluxioMasterInfo() - Constructor for class alluxio.wire.AlluxioMasterInfo
Creates a new instance of AlluxioMasterInfo.
AlluxioMasterMonitor - Class in alluxio.master
Alluxio master monitor for inquiring the AlluxioMaster service availability.
AlluxioMasterProcess - Class in alluxio.master
An Alluxio Master which runs a web and rpc server to handle FileSystem operations.
AlluxioMasterProcess(JournalSystem, PrimarySelector) - Constructor for class alluxio.master.AlluxioMasterProcess
Creates a new AlluxioMasterProcess.
AlluxioMasterProcess.Factory - Class in alluxio.master
Factory for creating AlluxioMasterProcess.
AlluxioMasterRestServiceHandler - Class in alluxio.master.meta
This class is a REST handler for requesting general master information.
AlluxioMasterRestServiceHandler(ServletContext) - Constructor for class alluxio.master.meta.AlluxioMasterRestServiceHandler
ALLUXIOONLY_FIELD_NUMBER - Static variable in class alluxio.grpc.DeletePOptions
 
ALLUXIOONLY_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.DeleteFileEntry
 
ALLUXIOPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.MountPRequest
 
ALLUXIOPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.ReverseResolvePResponse
 
ALLUXIOPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.UnmountPRequest
 
ALLUXIOPATH_FIELD_NUMBER - Static variable in class alluxio.grpc.UpdateMountPRequest
 
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
 
AlluxioProxy - Class in alluxio.proxy
Entry point for the Alluxio proxy program.
AlluxioProxyInfo - Class in alluxio.wire
Alluxio proxy information.
AlluxioProxyInfo() - Constructor for class alluxio.wire.AlluxioProxyInfo
Creates a new instance of AlluxioProxyInfo.
AlluxioProxyMonitor - Class in alluxio.proxy
Alluxio proxy monitor for inquiring the AlluxioProxy service availability.
AlluxioProxyProcess - Class in alluxio.proxy
This class encapsulates the different worker services that are configured to run.
AlluxioProxyRestServiceHandler - Class in alluxio.proxy
This class is a REST handler for requesting general proxy information.
AlluxioProxyRestServiceHandler(ServletContext) - Constructor for class alluxio.proxy.AlluxioProxyRestServiceHandler
AlluxioReadWorker(int, int, int, ByteBuffer, FileSystem) - Constructor for class alluxio.examples.Performance.AlluxioReadWorker
 
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
 
AlluxioS3Exception - Exception in alluxio.underfs.s3a
Alluxio exception for s3.
AlluxioSimpleMasterProcess - Class in alluxio.master
This class is responsible for initializing the different masters that are configured to run.
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(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.
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.
ALLUXIOVERSION_FIELD_NUMBER - Static variable in class alluxio.proto.client.Cache.PPageStoreCommonOptions
 
AlluxioWorker - Class in alluxio.worker
Entry point for the Alluxio worker.
AlluxioWorkerInfo - Class in alluxio.wire
Alluxio worker information.
AlluxioWorkerInfo() - Constructor for class alluxio.wire.AlluxioWorkerInfo
Creates a new instance of AlluxioWorkerInfo.
AlluxioWorkerMonitor - Class in alluxio.worker
Alluxio worker monitor for inquiring AlluxioWorker service availability.
AlluxioWorkerProcess - Class in alluxio.worker
This class encapsulates the different worker services that are configured to run.
AlluxioWorkerProcess(WorkerRegistry, UfsManager, Worker, DataServerFactory, NettyDataServer, HttpServer, boolean) - Constructor for class alluxio.worker.AlluxioWorkerProcess
Creates a new instance of AlluxioWorkerProcess.
AlluxioWorkerProcessModule - Class in alluxio.worker.modules
Grpc worker module.
AlluxioWorkerProcessModule() - Constructor for class alluxio.worker.modules.AlluxioWorkerProcessModule
 
AlluxioWriterWorker(int, int, int, ByteBuffer, FileSystem) - Constructor for class alluxio.examples.Performance.AlluxioWriterWorker
 
ALREADY_EXISTS_VALUE - Static variable in enum alluxio.proto.status.Status.PStatus
AlreadyExists means an attempt to create an entity failed because one already exists.
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(Throwable) - Constructor for exception alluxio.exception.status.AlreadyExistsException
 
AlreadyExistsException(String, 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(Throwable) - Constructor for exception alluxio.exception.runtime.AlreadyExistsRuntimeException
Constructor.
AlreadyExistsRuntimeException(String) - Constructor for exception alluxio.exception.runtime.AlreadyExistsRuntimeException
Constructor.
altIndex(int, int, int) - Static method in class alluxio.client.file.cache.cuckoofilter.CuckooUtils
Compute the alternative index on given hash value and tag.
ALWAYS - Static variable in interface alluxio.master.file.meta.UfsAbsentPathCache
 
ALWAYS - Static variable in class alluxio.master.predicate.interval.Interval
The interval that is always possible.
ALWAYS - Static variable in class alluxio.master.predicate.interval.IntervalSet
The interval set that is always possible.
ALWAYS_VALUE - Static variable in enum alluxio.grpc.LoadMetadataPType
Always load metadata.
AlwaysStandbyPrimarySelector - Class in alluxio.master
A primary selector which is always standby.
AlwaysStandbyPrimarySelector() - Constructor for class alluxio.master.AlwaysStandbyPrimarySelector
 
and(Mode, Mode) - Static method in class alluxio.security.authorization.Mode
 
and(Mode.Bits) - Method in enum alluxio.security.authorization.Mode.Bits
 
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.cli.CheckCluster
 
ANSI_GREEN - Static variable in class alluxio.Constants
 
ANSI_PURPLE - Static variable in class alluxio.Constants
 
ANSI_RED - Static variable in class alluxio.cli.CheckCluster
 
ANSI_RED - Static variable in class alluxio.Constants
 
ANSI_RESET - Static variable in class alluxio.cli.CheckCluster
 
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_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(PageId, int, byte[], CacheContext) - Method in interface alluxio.client.file.cache.CacheManager
 
append(PageId, int, byte[], CacheContext) - Method in class alluxio.client.file.cache.CacheManagerWithShadowCache
 
append(PageId, int, byte[], CacheContext) - Method in class alluxio.client.file.cache.LocalCacheManager
 
append(PageId, int, byte[], CacheContext) - Method in class alluxio.client.file.cache.NoExceptionCacheManager
 
append(Path, int, Progressable) - Method in class alluxio.hadoop.AbstractFileSystem
 
append(Path, int, Progressable) - Method in class alluxio.hadoop.LocalCacheFileSystem
 
append(AuditContext) - Method in class alluxio.master.audit.AsyncUserAccessAuditLogWriter
Appends an AuditContext.
append(Journal.JournalEntry) - Method in class alluxio.master.journal.FileSystemMergeJournalContext
Adds the new journal entry into the journal entry merger.
append(Journal.JournalEntry) - Method in interface alluxio.master.journal.JournalContext
 
append(Journal.JournalEntry) - Method in class alluxio.master.journal.MasterJournalContext
 
append(Journal.JournalEntry) - Method in class alluxio.master.journal.MergeJournalContext
 
append(Journal.JournalEntry) - Method in class alluxio.master.journal.NoopJournalContext
 
append(Journal.JournalEntry) - Method in interface alluxio.master.journal.sink.JournalSink
Appends a new journal entry written to the journal.
append(Journal.JournalEntry) - Method in class alluxio.master.journal.StateChangeJournalContext
 
append(ByteBuffer) - Method in class alluxio.worker.block.io.BlockWriter
Appends data to the end of a block from an input ByteBuffer.
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(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(ByteBuffer) - Method in class alluxio.worker.dora.PagedFileWriter
 
append(ByteBuf) - Method in class alluxio.worker.dora.PagedFileWriter
 
append(DataBuffer) - Method in class alluxio.worker.dora.PagedFileWriter
 
appendEntry(Journal.JournalEntry) - Method in class alluxio.master.journal.AsyncJournalWriter
Appends a Journal.JournalEntry for writing to the journal.
appendEntry(Journal.JournalEntry) - Method in class alluxio.master.journalv0.AsyncJournalWriter
Appends a Journal.JournalEntry for writing to the journal.
appendMergedJournals() - Method in class alluxio.master.journal.FileSystemMergeJournalContext
 
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.
ApplicableUfsType - Annotation Type in alluxio.cli
An enum standing for a UFS type.
ApplicableUfsType.Type - Enum in alluxio.cli
UFS types.
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(A, B, C) - Method in interface alluxio.collections.TwoKeyConcurrentMap.TriFunction
 
apply(long, long, String, FileStat, long) - Static method in class alluxio.jnifuse.FuseFillDir
 
apply(Clients) - Method in class alluxio.master.backcompat.FsTestOp
 
apply(FileSystem) - Method in class alluxio.master.backcompat.FsTestOp
 
apply(FileSystem) - Method in class alluxio.master.backcompat.ops.AsyncPersist
 
apply(FileSystem) - Method in class alluxio.master.backcompat.ops.CreateDirectory
 
apply(FileSystem) - Method in class alluxio.master.backcompat.ops.CreateFile
 
apply(FileSystem) - Method in class alluxio.master.backcompat.ops.Delete
 
apply(FileSystem) - Method in class alluxio.master.backcompat.ops.Mount
 
apply(FileSystem) - Method in class alluxio.master.backcompat.ops.PersistDirectory
 
apply(Clients) - Method in class alluxio.master.backcompat.ops.PersistFile
 
apply(FileSystem) - Method in class alluxio.master.backcompat.ops.Rename
 
apply(FileSystem) - Method in class alluxio.master.backcompat.ops.SetAcl
 
apply(Clients) - Method in class alluxio.master.backcompat.ops.UpdateUfsMode
 
apply(Clients) - Method in interface alluxio.master.backcompat.TestOp
Applies the test operation.
apply(FileSystem, FileSystem, String, String, String) - Static method in class alluxio.proxy.s3.MultipartUploadCleaner
Schedule a task to clean multipart upload.
apply() - Method in interface alluxio.underfs.ObjectUnderFileSystem.ObjectStoreOperation
Applies this operation.
applyAndJournal(Supplier<JournalContext>, File.DeleteFileEntry) - Method in class alluxio.master.file.meta.InodeTreePersistentState
Deletes an inode (may be either a file or directory).
applyAndJournal(Supplier<JournalContext>, File.NewBlockEntry) - Method in class alluxio.master.file.meta.InodeTreePersistentState
Allocates and returns the next block ID for the indicated inode.
applyAndJournal(Supplier<JournalContext>, File.RenameEntry) - Method in class alluxio.master.file.meta.InodeTreePersistentState
Renames an inode.
applyAndJournal(Supplier<JournalContext>, File.SetAclEntry) - Method in class alluxio.master.file.meta.InodeTreePersistentState
Sets an ACL for an inode.
applyAndJournal(Supplier<JournalContext>, File.UpdateInodeEntry) - Method in class alluxio.master.file.meta.InodeTreePersistentState
Updates an inode's state.
applyAndJournal(Supplier<JournalContext>, File.UpdateInodeDirectoryEntry) - Method in class alluxio.master.file.meta.InodeTreePersistentState
Updates an inode directory's state.
applyAndJournal(Supplier<JournalContext>, File.UpdateInodeFileEntry) - Method in class alluxio.master.file.meta.InodeTreePersistentState
Updates an inode file's state.
applyAndJournal(Supplier<JournalContext>, MutableInode<?>, String) - Method in class alluxio.master.file.meta.InodeTreePersistentState
Adds an inode to the inode tree.
applyAndJournal(Supplier<JournalContext>, File.AddMountPointEntry) - Method in class alluxio.master.file.meta.MountTable.State
 
applyAndJournal(Supplier<JournalContext>, File.DeleteMountPointEntry) - Method in class alluxio.master.file.meta.MountTable.State
 
applyAndJournal(Supplier<JournalContext>, Journal.JournalEntry) - Method in interface alluxio.master.journal.DelegatingJournaled
 
applyAndJournal(Supplier<JournalContext>, Journal.JournalEntry) - Method in interface alluxio.master.journal.Journaled
Applies and journals a journal entry.
applyAndJournal(Supplier<JournalContext>, String) - Method in class alluxio.master.meta.DefaultMetaMaster.State
 
applyAndJournal(Supplier<JournalContext>, Meta.PathPropertiesEntry) - Method in class alluxio.master.meta.PathProperties.State
 
applyAndJournal(Supplier<JournalContext>, Meta.RemovePathPropertiesEntry) - Method in class alluxio.master.meta.PathProperties.State
 
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.
applyInodeAccessTime(long, long) - Method in class alluxio.master.file.meta.InodeTreePersistentState
Updates last access time for Inode without journaling.
applyJournalEntryCommand(TransactionContext) - Method in class alluxio.master.journal.raft.JournalStateMachine
Applies a journal entry commit to the state machine.
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>, Executor) - 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 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.
applyTransaction(TransactionContext) - Method in class alluxio.master.journal.raft.JournalStateMachine
 
approximateContentHash(long, long) - Static method in class alluxio.util.UnderFileSystemUtils
Returns an approximate content hash, using the length and modification time.
approximateElementCount() - Method in interface alluxio.client.file.cache.cuckoofilter.ClockCuckooFilter
 
approximateElementCount(CacheScope) - Method in interface alluxio.client.file.cache.cuckoofilter.ClockCuckooFilter
 
approximateElementCount() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
approximateElementCount(CacheScope) - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
approximateElementSize() - Method in interface alluxio.client.file.cache.cuckoofilter.ClockCuckooFilter
 
approximateElementSize(CacheScope) - Method in interface alluxio.client.file.cache.cuckoofilter.ClockCuckooFilter
 
approximateElementSize() - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
approximateElementSize(CacheScope) - Method in class alluxio.client.file.cache.cuckoofilter.ConcurrentClockCuckooFilter
 
areDescendantsLoaded(InodeDirectoryView) - Method in class alluxio.master.file.DefaultFileSystemMaster
 
argsToString(String, T...) - Static method in class alluxio.util.CommonUtils
Converts varargs of objects to a string.
asAsyncCacheRequest() - Method in class alluxio.util.proto.ProtoMessage
 
ASCENDING_VALUE - Static variable in enum alluxio.grpc.table.layout.hive.SortingColumn.SortingOrder
ASCENDING = 0;
asDirectory() - Method in class alluxio.master.file.meta.Inode
Casts the inode as an InodeDirectory if it is one, otherwise throws an exception.
asDirectory() - Method in class alluxio.master.file.meta.MutableInode
Casts the inode as an InodeDirectory if it is one, otherwise throws an exception.
asFile() - Method in class alluxio.master.file.meta.Inode
 
asFile() - Method in class alluxio.master.file.meta.MutableInode
 
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.
assertAllLocksReleased() - Method in class alluxio.master.file.meta.InodeLockManager
Asserts that all locks have been released, throwing an exception if any locks are still taken.
assertAllLocksReleased(LocalAlluxioCluster) - Static method in class alluxio.master.TestUtils
Verifies that all master inode tree locks have been released for the given cluster.
assertValidPort(int) - Static method in class alluxio.util.network.NetworkAddressUtils
Checks if the given port is valid.
asUfsFileStatus() - Method in class alluxio.underfs.UfsStatus
 
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_FIELD_NUMBER - Static variable in class alluxio.grpc.CacheRequest
 
ASYNC_OPTION - Static variable in class alluxio.cli.fs.command.AbstractDistributedJobCommand
 
ASYNC_PERSIST_REQUEST_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
ASYNC_THROUGH_VALUE - Static variable in enum alluxio.grpc.WritePType
Deprecated.
AsyncBenchThreadState() - Constructor for class alluxio.fsmaster.FileSystemBench.AsyncBenchThreadState
 
asyncCache(AsyncCacheRequest, StreamObserver<AsyncCacheResponse>) - Method in interface alluxio.grpc.BlockWorkerGrpc.AsyncService
 
asyncCache(AsyncCacheRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
 
asyncCache(AsyncCacheRequest) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
 
asyncCache(AsyncCacheRequest, StreamObserver<AsyncCacheResponse>) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
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)
AsyncCacheRequest - Class in alluxio.grpc
Request for caching a block asynchronously Deprecated and will be removed in v3.0
AsyncCacheRequest.Builder - Class in alluxio.grpc
Request for caching a block asynchronously Deprecated and will be removed in v3.0
AsyncCacheRequestOrBuilder - Interface in alluxio.grpc
 
AsyncCacheResponse - Class in alluxio.grpc
Response for an async cache request
AsyncCacheResponse.Builder - Class in alluxio.grpc
Response for an async cache request
AsyncCacheResponseOrBuilder - Interface in alluxio.grpc
 
asyncGetStatusBench(Blackhole, FileSystemBench.AsyncBenchThreadState) - Method in class alluxio.fsmaster.FileSystemBench
 
AsyncJournalWriter - Class in alluxio.master.journal
This enables async journal writing, as well as some batched journal flushing.
AsyncJournalWriter(JournalWriter, Supplier<Set<JournalSink>>) - Constructor for class alluxio.master.journal.AsyncJournalWriter
AsyncJournalWriter(JournalWriter, Supplier<Set<JournalSink>>, String) - Constructor for class alluxio.master.journal.AsyncJournalWriter
AsyncJournalWriter - Class in alluxio.master.journalv0
This enables async journal writing, as well as some batched journal flushing.
AsyncJournalWriter(JournalWriter) - Constructor for class alluxio.master.journalv0.AsyncJournalWriter
AsyncPersist - Class in alluxio.master.backcompat.ops
Test for async persist functionality.
AsyncPersist() - Constructor for class alluxio.master.backcompat.ops.AsyncPersist
 
AsyncPersistHandler - Interface in alluxio.master.file.async
The handler that handles the scheduled async persist requests on files, and decides which worker to take the persistence task.
AsyncPersistHandler.Factory - Class in alluxio.master.file.async
Factory for AsyncPersistHandler.
ASYNCPERSISTOPTIONS_FIELD_NUMBER - Static variable in class alluxio.grpc.CompleteFilePOptions
 
AsyncUfsAbsentPathCache - Class in alluxio.master.file.meta
This is a UfsAbsentPathCache which implements asynchronous addition and removal to the cache, since the processing of the path may be slow.
AsyncUfsAbsentPathCache(MountTable, int, Clock) - Constructor for class alluxio.master.file.meta.AsyncUfsAbsentPathCache
Creates a new instance of AsyncUfsAbsentPathCache.
AsyncUfsClient - Interface in alluxio.underfs
The async UFS client interface.
asyncUpdateFileAccessTime(AlluxioURI) - Method in class alluxio.client.file.MetadataCachingFileSystem
Asynchronously update file's last access time.
AsyncUserAccessAuditLogWriter - Class in alluxio.master.audit
AsyncUserAccessAuditLogWriter writes user access audit log entries asynchronously.
AsyncUserAccessAuditLogWriter(String) - Constructor for class alluxio.master.audit.AsyncUserAccessAuditLogWriter
Constructs an AsyncUserAccessAuditLogWriter instance.
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.
attachDatabase(String, String, String, String, Map<String, String>, boolean) - Method in class alluxio.client.table.RetryHandlingTableMasterClient
 
attachDatabase(String, String, String, String, Map<String, String>, boolean) - Method in interface alluxio.client.table.TableMasterClient
Attaches an existing database.
attachDatabase(AttachDatabasePRequest, StreamObserver<AttachDatabasePResponse>) - Method in interface alluxio.grpc.table.TableMasterClientServiceGrpc.AsyncService
Attach an existing database into the catalog as a new database name
attachDatabase(AttachDatabasePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceBlockingStub
Attach an existing database into the catalog as a new database name
attachDatabase(AttachDatabasePRequest) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceFutureStub
Attach an existing database into the catalog as a new database name
attachDatabase(AttachDatabasePRequest, StreamObserver<AttachDatabasePResponse>) - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceStub
Attach an existing database into the catalog as a new database name
AttachDatabasePRequest - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.AttachDatabasePRequest
AttachDatabasePRequest.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.AttachDatabasePRequest
AttachDatabasePRequestOrBuilder - Interface in alluxio.grpc.table
 
AttachDatabasePResponse - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.AttachDatabasePResponse
AttachDatabasePResponse.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.AttachDatabasePResponse
AttachDatabasePResponseOrBuilder - Interface in alluxio.grpc.table
 
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
 
AuditContext - Interface in alluxio.master.audit
Context for Alluxio audit logging.
authenticate(AuthType, Subject, AlluxioConfiguration) - Method in class alluxio.grpc.GrpcChannel
 
authenticate(AuthType, Subject, AlluxioConfiguration, SaslClientHandler) - Method in class alluxio.grpc.GrpcChannel
 
authenticate(StreamObserver<SaslMessage>) - Method in interface alluxio.grpc.SaslAuthenticationServiceGrpc.AsyncService
Used to drive Sasl negotiation with clients.
authenticate(StreamObserver<SaslMessage>) - Method in class alluxio.grpc.SaslAuthenticationServiceGrpc.SaslAuthenticationServiceStub
Used to drive Sasl negotiation with clients.
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(StreamObserver<SaslMessage>) - Method in class alluxio.security.authentication.DefaultAuthenticationServer
 
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
 
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
AUTHENTICATIONSCHEME_FIELD_NUMBER - Static variable in class alluxio.grpc.SaslMessage
 
AuthenticationServer - Interface in alluxio.security.authentication
Interface for authentication server implementations.
AuthenticationServerProto - Class in alluxio.grpc
 
AuthenticationUtils - Class in alluxio.security.authentication
This class provides util methods for AuthenticationUtilss.
Authenticator - Interface in alluxio.s3.auth
Interface to authenticate.
AUTHENTICATOR - Static variable in class alluxio.s3.NettyRestUtils
 
Authenticator.Factory - Class in alluxio.s3.auth
Factory to create Authenticator.
AUTHINFO_CREATION_ERROR - Static variable in class alluxio.s3.S3ErrorCode
 
AUTHINFO_CREATION_ERROR - Static variable in class alluxio.s3.S3ErrorCode.Name
 
authority() - Method in class alluxio.grpc.GrpcChannel
 
Authority - Interface in alluxio.uri
This interface represents the authority part of a URI.
AUTHORIZATION_CHARSET - Static variable in class alluxio.s3.S3Constants
 
AUTHORIZATION_HEADER_MALFORMED - Static variable in class alluxio.s3.S3ErrorCode
 
AUTHORIZATION_HEADER_MALFORMED - Static variable in class alluxio.s3.S3ErrorCode.Name
 
AuthorizationV4Validator - Class in alluxio.s3.signature
AWS v4 authentication payload validator.
AuthPolicy - Interface in alluxio.fuse.auth
Fuse Auth Policy Interface.
AuthPolicyFactory - Class in alluxio.fuse.auth
Fuse Auth Policy Factory.
AuthPolicyFactory() - Constructor for class alluxio.fuse.auth.AuthPolicyFactory
 
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() - Method in interface alluxio.client.file.cache.CacheUsageView
Bytes that are available for caching.
available() - Method in class alluxio.client.file.cache.CacheUsageView.ImmutableCacheUsageView
 
available() - Method in class alluxio.hadoop.AlluxioHdfsInputStream
 
available() - Method in class alluxio.hadoop.BaseHdfsFileInputStream
 
available() - Method in class alluxio.underfs.cephfs.CephInputStream
 
available() - Method in class alluxio.underfs.hdfs.HdfsPositionedUnderFileInputStream
 
available() - Static method in class alluxio.underfs.UnderFileSystemFactoryRegistry
Returns a read-only view of the available base factories.
AVAILABLE_VALUE - Static variable in enum alluxio.grpc.QuorumServerState
AVAILABLE = 1;
AVG_COL_LEN_FIELD_NUMBER - Static variable in class alluxio.grpc.table.BinaryColumnStatsData
 
AVG_COL_LEN_FIELD_NUMBER - Static variable in class alluxio.grpc.table.StringColumnStatsData
 
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.
awaitLosePrimacy() - Method in class alluxio.master.journal.ufs.UfsJournal
Transitions the journal from primary to standby mode.
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(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() - Method in class alluxio.grpc.GrpcServer
Waits until the server is terminated.
awaitTermination(long, TimeUnit) - Method in class alluxio.master.AlluxioExecutorService
 
awaitTermination(boolean) - Method in class alluxio.master.journal.ufs.UfsJournalCheckpointThread
Initiates the shutdown of this checkpointer thread, and also waits for it to finish.
awaitTermination(long, TimeUnit) - Method in class alluxio.metrics.InstrumentedExecutorService
 
awaitTermination(long, TimeUnit) - Method in class alluxio.util.executor.ControllableScheduler
 
awaitTermination() - Method in interface alluxio.worker.DataServer
Waits for server to terminate.
awaitTermination() - Method in class alluxio.worker.grpc.GrpcDataServer
 
awaitTermination() - Method in class alluxio.worker.netty.NettyDataServer
 
AWS_ACCESS_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
AWS_SECRET_KEY - Static variable in class alluxio.conf.PropertyKey.Name
 
AwsAuthInfo - Class in alluxio.s3.auth
AWSAuthInfo wraps the data needed for AWS authentication.
AwsAuthInfo(String, String, String) - Constructor for class alluxio.s3.auth.AwsAuthInfo
 
AwsAuthV2HeaderParserUtils - Class in alluxio.s3.signature.utils
Util to parse V2 auth information from header.
AwsAuthV2HeaderParserUtils() - Constructor for class alluxio.s3.signature.utils.AwsAuthV2HeaderParserUtils
 
AwsAuthV4HeaderParserUtils - Class in alluxio.s3.signature.utils
Util to parse v4 auth information from header.
AwsAuthV4HeaderParserUtils() - Constructor for class alluxio.s3.signature.utils.AwsAuthV4HeaderParserUtils
 
AwsAuthV4QueryParserUtils - Class in alluxio.s3.signature.utils
Util for getting auth info from query parameters.
AwsAuthV4QueryParserUtils() - Constructor for class alluxio.s3.signature.utils.AwsAuthV4QueryParserUtils
 
AwsCredential - Class in alluxio.s3.signature
Credential in the AWS authorization header.
AwsSignatureProcessor - Class in alluxio.s3.signature
Parser to process AWS V2 & V4 auth request.
AwsSignatureProcessor(ContainerRequestContext) - Constructor for class alluxio.s3.signature.AwsSignatureProcessor
Create a new AwsSignatureProcessor.
AwsSignatureProcessor(HttpServletRequest) - Constructor for class alluxio.s3.signature.AwsSignatureProcessor
Create a new AwsSignatureProcessor with HttpServletRequest as the info marshall source.
AwsSignatureProcessor(HttpRequest) - Constructor for class alluxio.s3.signature.AwsSignatureProcessor
Create a new AwsSignatureProcessor with HttpRequest as the info marshall source.

B

BackoffStrategy - Enum in alluxio.worker.block.management
Used to specify from where to back-off.
backup(BackupPRequest) - Method in interface alluxio.client.meta.MetaMasterClient
Takes a backup.
backup(BackupPRequest) - Method in class alluxio.client.meta.RetryHandlingMetaMasterClient
 
backup(BackupPRequest, StreamObserver<BackupPStatus>) - Method in interface alluxio.grpc.MetaMasterClientServiceGrpc.AsyncService
Backs up the Alluxio master to the specified URI
backup(BackupPRequest) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceBlockingStub
Backs up the Alluxio master to the specified URI
backup(BackupPRequest) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceFutureStub
Backs up the Alluxio master to the specified URI
backup(BackupPRequest, StreamObserver<BackupPStatus>) - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceStub
Backs up the Alluxio master to the specified URI
backup(BackupPRequest, StateLockOptions) - Method in class alluxio.master.backup.BackupLeaderRole
 
backup(BackupPRequest, StateLockOptions) - Method in interface alluxio.master.backup.BackupOps
Takes a backup.
backup(BackupPRequest, StateLockOptions) - Method in class alluxio.master.backup.BackupWorkerRole
 
backup(OutputStream, AtomicLong) - Method in class alluxio.master.BackupManager
Writes a backup to the specified stream.
backup(BackupPRequest, StateLockOptions) - Method in class alluxio.master.meta.DefaultMetaMaster
 
backup(BackupPRequest, StreamObserver<BackupPStatus>) - Method in class alluxio.master.meta.MetaMasterClientServiceHandler
 
BACKUP_CONTENT_ON_RESTORE - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_DELEGATION_EMBEDDED - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_DELEGATION_FAILOVER_PROTOCOL - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_DELEGATION_PROTOCOL - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_DELEGATION_ZK - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_EMERGENCY_1 - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_EMERGENCY_2 - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_EMERGENCY_HA_1 - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_EMERGENCY_HA_2 - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_FILE_FORMAT - Static variable in class alluxio.master.BackupManager
The name format of the backup files (E.g., alluxio-backup-2018-12-14-1544749081561.gz).
BACKUP_FILE_PATTERN - Static variable in class alluxio.master.BackupManager
 
BACKUP_RESTORE_EMBEDDED - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_RESTORE_METASSTORE_HEAP - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_RESTORE_METASSTORE_ROCKS - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_RESTORE_SINGLE - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_RESTORE_ZK - Static variable in class alluxio.multi.process.PortCoordination
 
BACKUP_SYNC_ON_RESTORE - Static variable in class alluxio.multi.process.PortCoordination
 
BackupAbortedException - Exception in alluxio.exception
Thrown when backup is aborted.
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.
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.
BackupCommand - Class in alluxio.cli.fsadmin.command
Command for backing up Alluxio master metadata.
BackupCommand(Context, AlluxioConfiguration) - Constructor for class alluxio.cli.fsadmin.command.BackupCommand
 
BackupDelegationException - Exception in alluxio.exception
Thrown when backup delegation fails.
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.
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.
BACKUPERROR_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPStatus
 
BackupException - Exception in alluxio.exception
Thrown when backup is fails.
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.
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.
BackupHandshakeMessage - Class in alluxio.master.backup
The backup message used for introducing backup-worker to leader.
BackupHandshakeMessage() - Constructor for class alluxio.master.backup.BackupHandshakeMessage
Empty constructor as per deserialization requirement.
BackupHandshakeMessage(String) - Constructor for class alluxio.master.backup.BackupHandshakeMessage
Creates a handshake message.
BackupHeartbeatMessage - Class in alluxio.master.backup
The backup message used for sending status of current backup to leader.
BackupHeartbeatMessage() - Constructor for class alluxio.master.backup.BackupHeartbeatMessage
Empty constructor as per deserialization requirement.
BackupHeartbeatMessage(BackupStatus) - Constructor for class alluxio.master.backup.BackupHeartbeatMessage
Creates a heartbeat message with given backup status.
BACKUPHOST_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPStatus
 
BACKUPID_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPStatus
 
BACKUPID_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupStatusPRequest
 
BackupLeaderRole - Class in alluxio.master.backup
Implementation of BackupRole for primary mode.
BackupLeaderRole(CoreMasterContext) - Constructor for class alluxio.master.backup.BackupLeaderRole
Creates a new backup leader.
BackupManager - Class in alluxio.master
Manages creating and restoring from backups.
BackupManager(MasterRegistry) - Constructor for class alluxio.master.BackupManager
 
BackupOps - Interface in alluxio.master.backup
Interface for backup operations.
BackupPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.BackupPOptions
BackupPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.BackupPOptions
BackupPOptionsOrBuilder - Interface in alluxio.grpc
 
BackupPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.BackupPRequest
BackupPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.BackupPRequest
BackupPRequestOrBuilder - Interface in alluxio.grpc
 
BackupPStatus - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.BackupPStatus
BackupPStatus.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.BackupPStatus
BackupPStatusOrBuilder - Interface in alluxio.grpc
 
BackupRequestMessage - Class in alluxio.master.backup
The backup message used for signaling follower to start taking the backup.
BackupRequestMessage() - Constructor for class alluxio.master.backup.BackupRequestMessage
Empty constructor as per deserialization requirement.
BackupRequestMessage(UUID, BackupPRequest, Map<String, Long>) - Constructor for class alluxio.master.backup.BackupRequestMessage
Creates a backup request message.
BackupRole - Interface in alluxio.master.backup
Interface for interacting with backup roles.
BackupState - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.meta.BackupState
BACKUPSTATE_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPStatus
 
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(UUID, BackupState) - Constructor for class alluxio.wire.BackupStatus
Creates a new backup status with existing Id.
BackupStatus(BackupStatus) - Constructor for class alluxio.wire.BackupStatus
Cloning constructor.
BackupStatusPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.BackupStatusPRequest
BackupStatusPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.meta.BackupStatusPRequest
BackupStatusPRequestOrBuilder - Interface in alluxio.grpc
 
BackupSuspendMessage - Class in alluxio.master.backup
The backup message used for signaling follower to suspend its journals.
BackupSuspendMessage() - Constructor for class alluxio.master.backup.BackupSuspendMessage
Empty constructor as per deserialization requirement.
BackupTracker - Class in alluxio.master.backup
Used to track and update status of a backup.
BackupTracker() - Constructor for class alluxio.master.backup.BackupTracker
Creates a tracker.
BACKUPURI_FIELD_NUMBER - Static variable in class alluxio.grpc.BackupPStatus
 
BackupWorkerRole - Class in alluxio.master.backup
Implementation of BackupRole for standby mode.
BackupWorkerRole(CoreMasterContext) - Constructor for class alluxio.master.backup.BackupWorkerRole
Creates a new backup worker.
BACKWARDS_COMPATIBILITY - Static variable in class alluxio.multi.process.PortCoordination
 
BackwardsCompatibilityJournalGenerator - Class in alluxio.master.backcompat
Generates journals for consumption by the BackwardsCompatibilityIntegrationTest.
BackwardsCompatibilityJournalGenerator() - Constructor for class alluxio.master.backcompat.BackwardsCompatibilityJournalGenerator
 
BAD_DIGEST - Static variable in class alluxio.s3.S3ErrorCode
 
BAD_DIGEST - Static variable in class alluxio.s3.S3ErrorCode.Name
 
BANDWIDTH_FIELD_NUMBER - Static variable in class alluxio.grpc.CopyJobPOptions
 
BANDWIDTH_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadJobPOptions
 
BANDWIDTH_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveJobPOptions
 
BANDWIDTH_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsReadOptions
 
BANDWIDTH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.CopyJobEntry
 
BANDWIDTH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.LoadJobEntry
 
BANDWIDTH_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Job.MoveJobEntry
 
BarGraph - Class in alluxio.stress.graph
A bar graph representation.
BarGraph(String, List<String>, String) - Constructor for class alluxio.stress.graph.BarGraph
Creates an instance.
BarGraph.Data - Class in alluxio.stress.graph
Class representing data for a bar graph.
BASE_LAYOUT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Partition
 
BASE_PATH - Static variable in class alluxio.membership.AlluxioEtcdClient
 
BaseFileStructure - Class in alluxio
Governs the file structure parameters inside a JMH micro bench.
BaseFileStructure() - Constructor for class alluxio.BaseFileStructure
 
BaseFileStructure.Distribution - Enum in alluxio
 
BaseHdfsFileInputStream - Class in alluxio.hadoop
An input stream for reading a file from HDFS.
BaseHdfsFileInputStream(FileSystem, AlluxioURI, FileSystem.Statistics) - Constructor for class alluxio.hadoop.BaseHdfsFileInputStream
Constructs a new stream for reading a file from HDFS.
BaseHdfsFileInputStream(FileInStream, FileSystem.Statistics) - Constructor for class alluxio.hadoop.BaseHdfsFileInputStream
Constructs a new stream for reading a file from HDFS.
BaseMaster - Class in alluxio.multi.process
Class for running and interacting with an Alluxio master in a separate process.
BaseMaster(File, Map<PropertyKey, Object>) - Constructor for class alluxio.multi.process.BaseMaster
 
BaseParameters - Class in alluxio.stress
This holds all the parameters.
BaseParameters() - Constructor for class alluxio.stress.BaseParameters
 
BaseThreadState - Class in alluxio
Captures commonly reused thread state such as ID and file name and depth to poll.
BaseThreadState() - Constructor for class alluxio.BaseThreadState
 
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
 
BaseValueConverter<T> - Class in alluxio.fuse.options
Base class for value converters.
BaseValueConverter(String) - Constructor for class alluxio.fuse.options.BaseValueConverter
Constructor.
BasicCheckpoint - Class in alluxio.cli
An example to show to how use Alluxio's API.
BasicCheckpoint(String, int, FileSystemContext) - Constructor for class alluxio.cli.BasicCheckpoint
 
BasicNonByteBufferOperations - Class in alluxio.cli
Basic example of using the FileSystem for writing to and reading from files.
BasicNonByteBufferOperations(AlluxioURI, ReadType, WriteType, boolean, int, FileSystemContext, WorkerNetAddress) - Constructor for class alluxio.cli.BasicNonByteBufferOperations
 
BasicOperations - Class in alluxio.cli
Example to show the basic operations of Alluxio.
BasicOperations(AlluxioURI, ReadType, WriteType, FileSystemContext, WorkerNetAddress) - Constructor for class alluxio.cli.BasicOperations
 
BatchedJobConfig - Class in alluxio.job.plan
The configuration of loading a file.
BatchedJobConfig(String, Set<Map<String, String>>) - Constructor for class alluxio.job.plan.BatchedJobConfig
 
BatchedJobDefinition - Class in alluxio.job.plan.batch
A simple loading job that loads the blocks of a file in a distributed and round-robin fashion.
BatchedJobDefinition() - Constructor for class alluxio.job.plan.batch.BatchedJobDefinition
Constructs a new BatchedJobDefinition.
BatchedJobDefinition.BatchedJobTask - Class in alluxio.job.plan.batch
A task representing loading a block into the memory of a worker.
BatchedJobDefinition.JobDefinitionFactory - Class in alluxio.job.plan.batch
Factory class for get the specific job definition.
BatchedJobTask(JobConfig, Serializable) - Constructor for class alluxio.job.plan.batch.BatchedJobDefinition.BatchedJobTask
 
batchIncrementForCancelStatus(BatchedJobConfig) - Static method in class alluxio.master.job.metrics.DistributedCmdMetrics
Increment for Cancel status for batch job.
batchIncrementForCompleteStatusWithRetry(BatchedJobConfig, FileSystem, RetryPolicy) - Static method in class alluxio.master.job.metrics.DistributedCmdMetrics
Increment for batch config for complete status.
batchIncrementForFailStatus(BatchedJobConfig) - Static method in class alluxio.master.job.metrics.DistributedCmdMetrics
Increment for Fail status for batch job.
BATCHSIZE_FIELD_NUMBER - Static variable in class alluxio.grpc.ListStatusPartialPOptions
 
before(long) - Static method in class alluxio.master.predicate.interval.Interval
 
beforeConnect() - Method in class alluxio.AbstractClient
This method is called before the connection is connected.
beforeConnect() - Method in class alluxio.AbstractMasterClient
 
beforeConnect() - Method in class alluxio.master.journal.raft.RaftJournalServiceClient
 
beforeDisconnect() - Method in class alluxio.AbstractClient
This method is called before the connection is disconnected.
beforeExecute(Thread, Runnable) - Method in class alluxio.worker.job.task.PausableThreadPoolExecutor
 
beforeShutdown() - Method in interface alluxio.master.journal.sink.JournalSink
Signals the sink that the journal is about to shutdown.
beforeStart(ClientCallStreamObserver<ReqT>) - Method in class alluxio.client.block.stream.DataMessageClientResponseObserver
 
belongsTo(BlockStoreLocation) - Method in class alluxio.worker.block.BlockStoreLocation
Returns whether this location belongs to the specific location.
BENCH_TIMEOUT - Static variable in class alluxio.stress.BaseParameters
 
Benchmark<T extends TaskResult> - Class in alluxio.stress.cli
Base class for all stress benchmarks.
Benchmark() - Constructor for class alluxio.stress.cli.Benchmark
 
Benchmark.MethodStatistics - Class in alluxio.stress.cli
 
Benchmark.ProfileInput - Class in alluxio.stress.cli
 
BenchParams() - Constructor for class alluxio.RpcUtilsBench.BenchParams
 
BenchStandaloneGrpcServer - Class in alluxio.fsmaster
 
BenchStandaloneGrpcServer() - Constructor for class alluxio.fsmaster.BenchStandaloneGrpcServer
 
between(long, long) - Static method in class alluxio.master.predicate.interval.Interval
 
BINARY_STATS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsData
 
BinaryColumnStatsData - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.BinaryColumnStatsData
BinaryColumnStatsData.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.BinaryColumnStatsData
BinaryColumnStatsDataOrBuilder - Interface in alluxio.grpc.table
 
bindService(BlockMasterClientServiceGrpc.AsyncService) - Static method in class alluxio.grpc.BlockMasterClientServiceGrpc
 
bindService() - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceImplBase
 
bindService(BlockMasterWorkerServiceGrpc.AsyncService) - Static method in class alluxio.grpc.BlockMasterWorkerServiceGrpc
 
bindService() - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceImplBase
 
bindService(BlockWorkerGrpc.AsyncService) - Static method in class alluxio.grpc.BlockWorkerGrpc
 
bindService() - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerImplBase
 
bindService(FileSystemMasterClientServiceGrpc.AsyncService) - Static method in class alluxio.grpc.FileSystemMasterClientServiceGrpc
 
bindService() - Method in class alluxio.grpc.FileSystemMasterClientServiceGrpc.FileSystemMasterClientServiceImplBase
 
bindService(FileSystemMasterJobServiceGrpc.AsyncService) - Static method in class alluxio.grpc.FileSystemMasterJobServiceGrpc
 
bindService() - Method in class alluxio.grpc.FileSystemMasterJobServiceGrpc.FileSystemMasterJobServiceImplBase
 
bindService(FileSystemMasterWorkerServiceGrpc.AsyncService) - Static method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc
 
bindService() - Method in class alluxio.grpc.FileSystemMasterWorkerServiceGrpc.FileSystemMasterWorkerServiceImplBase
 
bindService(JobMasterClientServiceGrpc.AsyncService) - Static method in class alluxio.grpc.JobMasterClientServiceGrpc
 
bindService() - Method in class alluxio.grpc.JobMasterClientServiceGrpc.JobMasterClientServiceImplBase
 
bindService(JobMasterMasterServiceGrpc.AsyncService) - Static method in class alluxio.grpc.JobMasterMasterServiceGrpc
 
bindService() - Method in class alluxio.grpc.JobMasterMasterServiceGrpc.JobMasterMasterServiceImplBase
 
bindService(JobMasterWorkerServiceGrpc.AsyncService) - Static method in class alluxio.grpc.JobMasterWorkerServiceGrpc
 
bindService() - Method in class alluxio.grpc.JobMasterWorkerServiceGrpc.JobMasterWorkerServiceImplBase
 
bindService(JournalMasterClientServiceGrpc.AsyncService) - Static method in class alluxio.grpc.JournalMasterClientServiceGrpc
 
bindService() - Method in class alluxio.grpc.JournalMasterClientServiceGrpc.JournalMasterClientServiceImplBase
 
bindService(MessagingServiceGrpc.AsyncService) - Static method in class alluxio.grpc.MessagingServiceGrpc
 
bindService() - Method in class alluxio.grpc.MessagingServiceGrpc.MessagingServiceImplBase
 
bindService(MetaMasterClientServiceGrpc.AsyncService) - Static method in class alluxio.grpc.MetaMasterClientServiceGrpc
 
bindService() - Method in class alluxio.grpc.MetaMasterClientServiceGrpc.MetaMasterClientServiceImplBase
 
bindService(MetaMasterConfigurationServiceGrpc.AsyncService) - Static method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc
 
bindService() - Method in class alluxio.grpc.MetaMasterConfigurationServiceGrpc.MetaMasterConfigurationServiceImplBase
 
bindService(MetaMasterMasterServiceGrpc.AsyncService) - Static method in class alluxio.grpc.MetaMasterMasterServiceGrpc
 
bindService() - Method in class alluxio.grpc.MetaMasterMasterServiceGrpc.MetaMasterMasterServiceImplBase
 
bindService(MetaMasterProxyServiceGrpc.AsyncService) - Static method in class alluxio.grpc.MetaMasterProxyServiceGrpc
 
bindService() - Method in class alluxio.grpc.MetaMasterProxyServiceGrpc.MetaMasterProxyServiceImplBase
 
bindService(MetricsMasterClientServiceGrpc.AsyncService) - Static method in class alluxio.grpc.MetricsMasterClientServiceGrpc
 
bindService() - Method in class alluxio.grpc.MetricsMasterClientServiceGrpc.MetricsMasterClientServiceImplBase
 
bindService(PolicyMasterClientServiceGrpc.AsyncService) - Static method in class alluxio.grpc.PolicyMasterClientServiceGrpc
 
bindService() - Method in class alluxio.grpc.PolicyMasterClientServiceGrpc.PolicyMasterClientServiceImplBase
 
bindService(RaftJournalServiceGrpc.AsyncService) - Static method in class alluxio.grpc.RaftJournalServiceGrpc
 
bindService() - Method in class alluxio.grpc.RaftJournalServiceGrpc.RaftJournalServiceImplBase
 
bindService(SaslAuthenticationServiceGrpc.AsyncService) - Static method in class alluxio.grpc.SaslAuthenticationServiceGrpc
 
bindService() - Method in class alluxio.grpc.SaslAuthenticationServiceGrpc.SaslAuthenticationServiceImplBase
 
bindService(ServiceVersionClientServiceGrpc.AsyncService) - Static method in class alluxio.grpc.ServiceVersionClientServiceGrpc
 
bindService() - Method in class alluxio.grpc.ServiceVersionClientServiceGrpc.ServiceVersionClientServiceImplBase
 
bindService(TableMasterClientServiceGrpc.AsyncService) - Static method in class alluxio.grpc.table.TableMasterClientServiceGrpc
 
bindService() - Method in class alluxio.grpc.table.TableMasterClientServiceGrpc.TableMasterClientServiceImplBase
 
BIT_VECTORS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.BinaryColumnStatsData
 
BIT_VECTORS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.BooleanColumnStatsData
 
BIT_VECTORS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DateColumnStatsData
 
BIT_VECTORS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DecimalColumnStatsData
 
BIT_VECTORS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.DoubleColumnStatsData
 
BIT_VECTORS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.LongColumnStatsData
 
BIT_VECTORS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.StringColumnStatsData
 
Bits - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.Bits
BITS_FIELD_NUMBER - Static variable in class alluxio.grpc.CheckAccessPOptions
 
BitSet - Interface in alluxio.collections
An interface of BitSet supports get/set/clear.
block() - Method in class alluxio.client.file.FileSystemContextReinitializer
Acquires the resource to block reinitialization.
block() - Method in interface alluxio.concurrent.jsr.ForkJoinPool.ManagedBlocker
Possibly blocks the current thread, for example waiting for a lock or condition.
Block - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.Block
Block(long, Block.BlockMeta) - Constructor for class alluxio.master.metastore.BlockMetaStore.Block
 
Block - Class in alluxio.proto.journal
 
Block - Class in alluxio.proto.meta
 
Block.BlockContainerIdGeneratorEntry - Class in alluxio.proto.journal
next available id: 2
Block.BlockContainerIdGeneratorEntry.Builder - Class in alluxio.proto.journal
next available id: 2
Block.BlockContainerIdGeneratorEntryOrBuilder - Interface in alluxio.proto.journal
 
Block.BlockInfoEntry - Class in alluxio.proto.journal
next available id: 3
Block.BlockInfoEntry.Builder - Class in alluxio.proto.journal
next available id: 3
Block.BlockInfoEntryOrBuilder - Interface in alluxio.proto.journal
 
Block.BlockLocation - Class in alluxio.proto.meta
Location metadata describing a block's location in a certain storage tier of a certain worker.
Block.BlockLocation.Builder - Class in alluxio.proto.meta
Location metadata describing a block's location in a certain storage tier of a certain worker.
Block.BlockLocationOrBuilder - Interface in alluxio.proto.meta
 
Block.BlockMeta - Class in alluxio.proto.meta
Block metadata.
Block.BlockMeta.Builder - Class in alluxio.proto.meta
Block metadata.
Block.BlockMetaOrBuilder - Interface in alluxio.proto.meta
 
Block.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.Block
Block.DeleteBlockEntry - Class in alluxio.proto.journal
next available id: 2
Block.DeleteBlockEntry.Builder - Class in alluxio.proto.journal
next available id: 2
Block.DeleteBlockEntryOrBuilder - Interface in alluxio.proto.journal
 
BLOCK_CONTAINER_ID_GENERATOR_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
BLOCK_COUNT_MULTIPLIER - Static variable in class alluxio.master.block.JvmSpaceReviewer
 
BLOCK_COUNT_VALUE - Static variable in enum alluxio.grpc.WorkerInfoField
BLOCK_COUNT = 10;
BLOCK_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockStatus
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.AsyncCacheRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.Block
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.CacheRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.MoveBlockRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.ReadRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.grpc.RemoveBlockRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.AsyncCacheRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCloseRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCompleteRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockCreateRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.LocalBlockOpenRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.ReadRequest
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Block.BlockInfoEntry
 
BLOCK_ID_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Block.DeleteBlockEntry
 
BLOCK_IDS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.CompleteFileEntry
 
BLOCK_INFO_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Journal.JournalEntry
 
BLOCK_LOCATION_FIELD_NUMBER - Static variable in class alluxio.proto.journal.Block.BlockInfoEntry
 
BLOCK_MASTER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
BLOCK_MASTER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
BLOCK_MASTER_CLIENT_SERVICE = 4;
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_VALUE - Static variable in enum alluxio.grpc.ServiceType
BLOCK_MASTER_WORKER_SERVICE = 5;
BLOCK_MASTER_WORKER_SERVICE_VERSION - Static variable in class alluxio.Constants
 
BLOCK_SIZE_BYTES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
BLOCK_SIZE_BYTES_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.UpdateInodeFileEntry
 
BLOCK_SIZE_BYTES_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
BLOCK_SIZE_FIELD_NUMBER - Static variable in class alluxio.grpc.UfsFileStatus
 
BLOCK_SIZE_FIELD_NUMBER - Static variable in class alluxio.proto.dataserver.Protocol.OpenUfsBlockOptions
 
BLOCK_STATUS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadResponse
 
BLOCK_WORKER_CLIENT_SERVICE_NAME - Static variable in class alluxio.Constants
 
BLOCK_WORKER_CLIENT_SERVICE_VALUE - Static variable in enum alluxio.grpc.ServiceType
BLOCK_WORKER_CLIENT_SERVICE = 17;
BLOCK_WORKER_CLIENT_SERVICE_VERSION - Static variable in class alluxio.Constants
 
BLOCK_WORKER_NAME - Static variable in class alluxio.Constants
 
BlockAlreadyExistsException - Exception in alluxio.exception
The exception thrown when a block already exists in Alluxio.
BlockAlreadyExistsException(String) - Constructor for exception alluxio.exception.BlockAlreadyExistsException
Constructs a new exception with the specified exception message.
BlockAlreadyExistsException(ExceptionMessage, Object...) - Constructor for exception alluxio.exception.BlockAlreadyExistsException
Constructs a new exception with the specified exception message and multiple parameters.
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.
BlockContainerIdGenerator - Class in alluxio.master.block
This class generates unique block container ids.
BlockContainerIdGenerator() - Constructor for class alluxio.master.block.BlockContainerIdGenerator
Creates a new instance of BlockContainerIdGenerator.
BLOCKCOUNT_FIELD_NUMBER - Static variable in class alluxio.grpc.GetRegisterLeasePRequest
 
BlockDeletionContext - Interface in alluxio.master.file
Interface for a class which gathers block deletion requests, then handles them during close.
BlockDeletionContext.BlockDeletionListener - Interface in alluxio.master.file
Interface for block deletion listeners.
BlockDoesNotExistException - Exception in alluxio.exception
The exception thrown when a block does not exist in Alluxio.
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.
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.
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 block ID.
BlockDoesNotExistRuntimeException(long, Throwable) - Constructor for exception alluxio.exception.runtime.BlockDoesNotExistRuntimeException
Constructs a new exception with the specified block ID and cause.
blockHeartbeat(BlockHeartbeatPRequest, StreamObserver<BlockHeartbeatPResponse>) - Method in interface alluxio.grpc.BlockMasterWorkerServiceGrpc.AsyncService
Periodic block worker heartbeat returns an optional command for the block worker to execute.
blockHeartbeat(BlockHeartbeatPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceBlockingStub
Periodic block worker heartbeat returns an optional command for the block worker to execute.
blockHeartbeat(BlockHeartbeatPRequest) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceFutureStub
Periodic block worker heartbeat returns an optional command for the block worker to execute.
blockHeartbeat(BlockHeartbeatPRequest, StreamObserver<BlockHeartbeatPResponse>) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub
Periodic block worker heartbeat returns an optional command for the block worker to execute.
blockHeartbeat(BlockHeartbeatPRequest, StreamObserver<BlockHeartbeatPResponse>) - Method in class alluxio.master.block.BlockMasterWorkerServiceHandler
 
BlockHeartbeatPOptions - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.BlockHeartbeatPOptions
BlockHeartbeatPOptions.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.BlockHeartbeatPOptions
BlockHeartbeatPOptionsOrBuilder - Interface in alluxio.grpc
 
BlockHeartbeatPRequest - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.BlockHeartbeatPRequest
BlockHeartbeatPRequest.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.BlockHeartbeatPRequest
BlockHeartbeatPRequestOrBuilder - Interface in alluxio.grpc
 
BlockHeartbeatPResponse - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.BlockHeartbeatPResponse
BlockHeartbeatPResponse.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.BlockHeartbeatPResponse
BlockHeartbeatPResponseOrBuilder - Interface in alluxio.grpc
 
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.
BLOCKID_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockIdList
 
BLOCKID_FIELD_NUMBER - Static variable in class alluxio.grpc.BlockInfo
 
BLOCKID_FIELD_NUMBER - Static variable in class alluxio.grpc.CommitBlockPRequest
 
BLOCKID_FIELD_NUMBER - Static variable in class alluxio.grpc.GetBlockInfoPRequest
 
BlockIdList - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.BlockIdList
BlockIdList.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.BlockIdList
BlockIdListOrBuilder - Interface in alluxio.grpc
 
BLOCKIDS_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
BLOCKIDS_FIELD_NUMBER - Static variable in class alluxio.grpc.PersistFile
 
BlockInfo - Class in alluxio.grpc
Contains the information of a block in Alluxio.
BlockInfo - Class in alluxio.wire
The block information.
BlockInfo() - Constructor for class alluxio.wire.BlockInfo
Creates a new instance of BlockInfo.
BlockInfo.Builder - Class in alluxio.grpc
Contains the information of a block in Alluxio.
BLOCKINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.FileBlockInfo
 
BLOCKINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetBlockInfoPResponse
 
BlockInfoException - Exception in alluxio.exception
The exception thrown when something with the block goes wrong, i.e.
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.
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.
BlockInfoOrBuilder - Interface in alluxio.grpc
 
BlockingBenchThreadState() - Constructor for class alluxio.fsmaster.FileSystemBench.BlockingBenchThreadState
 
blockingGetStatusBench(Blackhole, FileSystemBench.BlockingBenchThreadState) - Method in class alluxio.fsmaster.FileSystemBench
 
BlockLocation - Class in alluxio.grpc
Information about blocks.
BlockLocation - Class in alluxio.wire
The location of a block.
BlockLocation() - Constructor for class alluxio.wire.BlockLocation
Creates a new instance of BlockLocation.
BlockLocation.Builder - Class in alluxio.grpc
Information about blocks.
BlockLocationInfo - Class in alluxio.wire
The file block with location information.
BlockLocationInfo(FileBlockInfo, List<WorkerNetAddress>) - Constructor for class alluxio.wire.BlockLocationInfo
 
BlockLocationOrBuilder - Interface in alluxio.grpc
 
BlockLocationUtils - Class in alluxio.util.proto
An util class to create cached grpc block locations.
BlockLocationUtils() - Constructor for class alluxio.util.proto.BlockLocationUtils
 
BlockLock - Class in alluxio.worker.block
A resource lock for block.
BlockLock(long, Consumer<Long>) - Constructor for class alluxio.worker.block.BlockLock
 
BlockMapIterator - Class in alluxio.worker.block
Each iteration returns a list of LocationBlockIdListEntry which consists of blocks for one RegisterWorkerPRequest.
BlockMapIterator(Map<BlockStoreLocation, List<Long>>) - Constructor for class alluxio.worker.block.BlockMapIterator
Constructor.
BlockMapIterator(Map<BlockStoreLocation, List<Long>>, AlluxioConfiguration) - Constructor for class alluxio.worker.block.BlockMapIterator
Constructor.
BlockMaster - Interface in alluxio.master.block
Interface of the block master that manages the metadata for all the blocks and block workers in Alluxio.
BlockMasterClient - Interface in alluxio.client.block
A client to use for interacting with a block master.
BlockMasterClient - Class in alluxio.worker.block
A wrapper for the gRPC client to interact with the block master, used by alluxio worker.
BlockMasterClient(MasterClientContext) - Constructor for class alluxio.worker.block.BlockMasterClient
Creates a new instance of BlockMasterClient for the worker.
BlockMasterClient(MasterClientContext, InetSocketAddress) - Constructor for class alluxio.worker.block.BlockMasterClient
Creates a new instance of BlockMasterClient for the worker and connects to a specific master.
BlockMasterClient.Factory - Class in alluxio.client.block
Factory for BlockMasterClient.
BlockMasterClientPool - Class in alluxio.client.block
Class for managing block master clients.
BlockMasterClientPool(MasterClientContext) - Constructor for class alluxio.client.block.BlockMasterClientPool
Creates a new block master client pool.
BlockMasterClientPool - Class in alluxio.worker.block
Class for managing block master clients.
BlockMasterClientPool() - Constructor for class alluxio.worker.block.BlockMasterClientPool
Creates a new block master client pool.
BlockMasterClientPool(InetSocketAddress) - Constructor for class alluxio.worker.block.BlockMasterClientPool
Creates a new block master client pool.
BlockMasterClientServiceGrpc - Class in alluxio.grpc
This interface contains block master service endpoints for Alluxio clients.
BlockMasterClientServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains block master service endpoints for Alluxio clients.
BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service BlockMasterClientService.
BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service BlockMasterClientService.
BlockMasterClientServiceGrpc.BlockMasterClientServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service BlockMasterClientService.
BlockMasterClientServiceGrpc.BlockMasterClientServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service BlockMasterClientService.
BlockMasterClientServiceHandler - Class in alluxio.master.block
This class is a gRPC handler for block master RPCs invoked by an Alluxio client.
BlockMasterClientServiceHandler(BlockMaster) - Constructor for class alluxio.master.block.BlockMasterClientServiceHandler
Creates a new instance of BlockMasterClientServiceHandler.
BlockMasterClientServiceImplBase() - Constructor for class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceImplBase
 
BlockMasterFactory - Class in alluxio.master.block
Factory to create a BlockMaster instance.
BlockMasterFactory() - Constructor for class alluxio.master.block.BlockMasterFactory
Constructs a new BlockMasterFactory.
BlockMasterInfo - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.BlockMasterInfo
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.
BlockMasterInfo.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.BlockMasterInfo
BLOCKMASTERINFO_FIELD_NUMBER - Static variable in class alluxio.grpc.GetBlockMasterInfoPResponse
 
BlockMasterInfoField - Enum in alluxio.grpc
Protobuf enum alluxio.grpc.block.BlockMasterInfoField
BlockMasterInfoOrBuilder - Interface in alluxio.grpc
 
BlockMasterProto - Class in alluxio.grpc
 
BlockMasterWorkerServiceGrpc - Class in alluxio.grpc
This interface contains block master service endpoints for Alluxio workers.
BlockMasterWorkerServiceGrpc.AsyncService - Interface in alluxio.grpc
This interface contains block master service endpoints for Alluxio workers.
BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service BlockMasterWorkerService.
BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service BlockMasterWorkerService.
BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceImplBase - Class in alluxio.grpc
Base class for the server implementation of the service BlockMasterWorkerService.
BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service BlockMasterWorkerService.
BlockMasterWorkerServiceHandler - Class in alluxio.master.block
This class is a gRPC handler for block master RPCs invoked by an Alluxio worker.
BlockMasterWorkerServiceHandler(BlockMaster) - Constructor for class alluxio.master.block.BlockMasterWorkerServiceHandler
Creates a new instance of BlockMasterWorkerServiceHandler.
BlockMasterWorkerServiceImplBase() - Constructor for class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceImplBase
 
BlockMeta - Interface in alluxio.worker.block.meta
Metadata of a block in Alluxio managed storage served by workers.
BlockMetaStore - Interface in alluxio.master.metastore
The block store keeps track of block sizes and block locations.
BlockMetaStore.Block - Class in alluxio.master.metastore
Block metadata.
BlockMetaStore.Factory - Interface in alluxio.master.metastore
Factory for creating block stores.
BlockOrBuilder - Interface in alluxio.grpc
 
BlockPacketWriter(BlockWriteRequestContext, Channel, DoraWorker) - Constructor for class alluxio.worker.netty.FileWriteHandler.BlockPacketWriter
 
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.
BlockReadRequest - Class in alluxio.wire
The internal representation of a block read request.
BlockReadRequest - Class in alluxio.worker.netty
The internal representation of a block read request.
BlockReadRequest(Protocol.ReadRequest) - Constructor for class alluxio.worker.netty.BlockReadRequest
Creates an instance of BlockReadRequest.
BlockReadRequestContext - Class in alluxio.worker.grpc
Context of BlockReadRequest.
BlockReadRequestContext(ReadRequest) - Constructor for class alluxio.worker.grpc.BlockReadRequestContext
 
BlockReadRequestContext - Class in alluxio.worker.netty
Context of BlockReadRequest.
BlockReadRequestContext(Protocol.ReadRequest) - Constructor for class alluxio.worker.netty.BlockReadRequestContext
 
blockReinit() - Method in class alluxio.client.file.FileSystemContext
Acquires the resource to block reinitialization.
BLOCKS_FIELD_NUMBER - Static variable in class alluxio.grpc.LoadRequest
 
BLOCKS_FIELD_NUMBER - Static variable in class alluxio.proto.journal.File.InodeFileEntry
 
BLOCKS_FIELD_NUMBER - Static variable in class alluxio.proto.meta.InodeMeta.Inode
 
BLOCKSIZEBYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.CreateFilePOptions
 
BLOCKSIZEBYTES_FIELD_NUMBER - Static variable in class alluxio.grpc.FileInfo
 
BlockStatus - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.BlockStatus
BlockStatus.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.block.BlockStatus
BlockStatusOrBuilder - Interface in alluxio.grpc
 
BlockStore - Interface in alluxio.worker.block
An abstraction of block store on worker.
BlockStoreClient - Class in alluxio.client.block
Alluxio Block Store client.
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.
BlockStoreLocationProto - Class in alluxio.grpc
Protobuf type alluxio.grpc.BlockStoreLocationProto
BlockStoreLocationProto.Builder - Class in alluxio.grpc
Protobuf type alluxio.grpc.BlockStoreLocationProto
BlockStoreLocationProtoOrBuilder - Interface in alluxio.grpc
 
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.
BlockUtils - Class in alluxio.worker
Block related utils methods.
BlockWorker - Interface in alluxio.worker.block
A block worker in the Alluxio system.
BlockWorkerClient - Interface in alluxio.client.block.stream
gRPC client for worker communication.
BlockWorkerClient.Factory - Class in alluxio.client.block.stream
Factory for block worker client.
BlockWorkerClientPool - Class in alluxio.client.block.stream
Class for managing block worker clients.
BlockWorkerClientPool(UserState, GrpcServerAddress, int, int, AlluxioConfiguration) - Constructor for class alluxio.client.block.stream.BlockWorkerClientPool
Creates a new block master client pool.
BlockWorkerDataReader - Class in alluxio.client.block.stream
A data reader that reads from a worker in the same process of this client directly.
BlockWorkerDataReader.Factory - Class in alluxio.client.block.stream
Factory class to create BlockWorkerDataReaders.
BlockWorkerDataWriter - Class in alluxio.client.block.stream
A data writer that issues from a client embedded in a worker to write data to the worker directly via internal communication channel.
BlockWorkerGrpc - Class in alluxio.grpc
The block worker service
BlockWorkerGrpc.AsyncService - Interface in alluxio.grpc
The block worker service
BlockWorkerGrpc.BlockWorkerBlockingStub - Class in alluxio.grpc
A stub to allow clients to do synchronous rpc calls to service BlockWorker.
BlockWorkerGrpc.BlockWorkerFutureStub - Class in alluxio.grpc
A stub to allow clients to do ListenableFuture-style rpc calls to service BlockWorker.
BlockWorkerGrpc.BlockWorkerImplBase - Class in alluxio.grpc
Base class for the server implementation of the service BlockWorker.
BlockWorkerGrpc.BlockWorkerStub - Class in alluxio.grpc
A stub to allow clients to do asynchronous rpc calls to service BlockWorker.
BlockWorkerImplBase() - Constructor for class alluxio.grpc.BlockWorkerGrpc.BlockWorkerImplBase
 
BlockWorkerInfo - Class in alluxio.client.block
Information of an active block worker.
BlockWorkerInfo(WorkerNetAddress, long, long) - Constructor for class alluxio.client.block.BlockWorkerInfo
Constructs the block worker information.
BlockWorkerInfo(WorkerNetAddress, long, long, boolean) - Constructor for class alluxio.client.block.BlockWorkerInfo
Constructs the block worker information.
BlockWorkerMetrics - Class in alluxio.worker.block
The BlockMetaMetricCache cache the metric data of the BlockMeta from the BlockWorker.
BlockWorkerMetrics(long, long, long, Map<String, Long>, Map<String, Long>, Map<String, Long>, int) - Constructor for class alluxio.worker.block.BlockWorkerMetrics
construct func of BlockWorkerMetrics.
BlockWorkerProto - Class in alluxio.grpc
 
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.
BlockWriteRequest - Class in alluxio.worker.netty
The block write request internal representation.
BlockWriteRequestContext - Class in alluxio.worker.netty
The block write request internal representation.
BlockWriteRequestContext(Protocol.WriteRequest, long) - Constructor for class alluxio.worker.netty.BlockWriteRequestContext
 
BOOLEAN_STATS_FIELD_NUMBER - Static variable in class alluxio.grpc.table.ColumnStatisticsData
 
BOOLEAN_TYPE_FIELD_NUMBER - Static variable in class alluxio.grpc.table.Value
 
booleanBuilder(String) - Static method in class alluxio.conf.PropertyKey.Builder
 
BooleanColumnStatsData - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.BooleanColumnStatsData
BooleanColumnStatsData.Builder - Class in alluxio.grpc.table
Protobuf type alluxio.grpc.table.BooleanColumnStatsData
BooleanColumnStatsDataOrBuilder - Interface in alluxio.grpc.table
 
bossEventLoopGroup(EventLoopGroup) - Method in class alluxio.grpc.GrpcServerBuilder
Sets the boss EventLoopGroup.
BoundedPriorityBlockingQueue(int) - Constructor for class alluxio.master.scheduler.Scheduler.BoundedPriorityBlockingQueue
Constructor for Bounded priority queue with a max capacity.
BoundedStream - Interface in alluxio.client
This interface should be implemented by all Alluxio streams which are bounded at a certain byte size.
Bucket() - Constructor for class alluxio.s3.ListAllMyBucketsResult.Bucket
Creates a ListAllMyBucketsResult.Bucket for deserialization only.
BUCKET_ADJACENT_DOTS_DASHES_PATTERN - Static variable in class alluxio.proxy.s3.S3Handler
 
BUCKET_ADJACENT_DOTS_DASHES_PATTERN - Static variable in class alluxio.worker.s3.S3NettyHandler
 
BUCKET_ALREADY_EXISTS - Static variable in class alluxio.s3.S3ErrorCode
 
BUCKET_ALREADY_EXISTS - Static variable in class alluxio.s3.S3ErrorCode.Name
 
BUCKET_COUNT_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
BUCKET_INVALID_SUFFIX_PATTERN - Static variable in class alluxio.proxy.s3.S3Handler
 
BUCKET_INVALID_SUFFIX_PATTERN - Static variable in class alluxio.worker.s3.S3NettyHandler
 
BUCKET_INVALIDATION_PREFIX_PATTERN - Static variable in class alluxio.proxy.s3.S3Handler
 
BUCKET_INVALIDATION_PREFIX_PATTERN - Static variable in class alluxio.worker.s3.S3NettyHandler
 
BUCKET_NAMING_RESTRICTION_ENABLED - Static variable in class alluxio.proxy.s3.S3Handler
 
BUCKET_NAMING_RESTRICTION_ENABLED - Static variable in class alluxio.worker.s3.S3NettyHandler
 
BUCKET_NOT_EMPTY - Static variable in class alluxio.s3.S3ErrorCode
 
BUCKET_NOT_EMPTY - Static variable in class alluxio.s3.S3ErrorCode.Name
 
BUCKET_PARAM - Static variable in class alluxio.proxy.s3.S3RestServiceHandler
 
BUCKET_PATH_CACHE - Static variable in class alluxio.proxy.s3.S3Handler
 
BUCKET_PATH_CACHE - Static variable in class alluxio.worker.s3.S3NettyHandler
 
BUCKET_PATH_CACHE_SIZE - Static variable in class alluxio.proxy.s3.S3Handler
 
BUCKET_PATH_CACHE_SIZE - Static variable in class alluxio.proxy.s3.S3RestServiceHandler
 
BUCKET_PATH_CACHE_SIZE - Static variable in class alluxio.worker.s3.S3NettyHandler
 
BUCKET_PATH_PATTERN - Static variable in class alluxio.proxy.s3.S3Handler
 
BUCKET_PATH_PATTERN - Static variable in class alluxio.worker.s3.S3NettyHandler
 
BUCKET_PROPERTY_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.Storage
 
BUCKET_SEPARATOR - Static variable in class alluxio.s3.S3Constants
Bucket must be a directory directly under a mount point.
BUCKET_VALID_NAME_PATTERN - Static variable in class alluxio.proxy.s3.S3Handler
 
BUCKET_VALID_NAME_PATTERN - Static variable in class alluxio.worker.s3.S3NettyHandler
 
BucketCounter - Class in alluxio.util
Bucket Counter Utility.
BucketCounter(List<Long>) - Constructor for class alluxio.util.BucketCounter
Bucket Counter constructor.
BUCKETED_BY_FIELD_NUMBER - Static variable in class alluxio.grpc.table.layout.hive.HiveBucketProperty
 
buffer - Variable in class alluxio.jnifuse.struct.FuseFileInfo
 
BUFFER_SIZE - Static variable in class alluxio.master.journal.checkpoint.OptimizedCheckpointOutputStream
 
BUFFER_SIZE_OPTION - Static variable in class alluxio.cli.fs.command.CpCommand
 
BufferCachingGrpcDataReader - Class in alluxio.client.block.stream
A gRPC data reader that responsible for reading from a specific block.
BufferCachingGrpcDataReader(WorkerNetAddress, CloseableResource<BlockWorkerClient>, long, ReadRequest, GrpcBlockingStream<ReadRequest, ReadResponse>) - Constructor for class alluxio.client.block.stream.BufferCachingGrpcDataReader
Creates an instance of BufferCachingGrpcDataReader.
BufferedJournalApplier - Class in alluxio.master.journal.raft
Used to control applying to masters.
BufferedJournalApplier(Map<String, RaftJournal>, Supplier<Set<JournalSink>>) - Constructor for class alluxio.master.journal.raft.BufferedJournalApplier
Creates a buffered applier over given journals.
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.client.file.options.FileSystemOptions.Builder
 
build() - Method in class alluxio.conf.PropertyKey.Builder
Creates and registers the property key.
build() - Method in class alluxio.fuse.options.FuseOptions.Builder
Builds Fuse options.
build() - Method in class alluxio.grpc.ActionInfo.Builder
 
build() - Method in class alluxio.grpc.AddPolicyPOptions.Builder
 
build() - Method in class alluxio.grpc.AddPolicyPRequest.Builder
 
build() - Method in class alluxio.grpc.AddPolicyPResponse.Builder
 
build() - Method in class alluxio.grpc.AddQuorumServerRequest.Builder
 
build() - Method in class alluxio.grpc.AsyncCacheRequest.Builder
 
build() - Method in class alluxio.grpc.AsyncCacheResponse.Builder
 
build() - Method in class alluxio.grpc.BackupPOptions.Builder
 
build() - Method in class alluxio.grpc.BackupPRequest.Builder
 
build() - Method in class alluxio.grpc.BackupPStatus.Builder
 
build() - Method in class alluxio.grpc.BackupStatusPRequest.Builder
 
build() - Method in class alluxio.grpc.Block.Builder
 
build() - Method in class alluxio.grpc.BlockHeartbeatPOptions.Builder
 
build() - Method in class alluxio.grpc.BlockHeartbeatPRequest.Builder
 
build() - Method in class alluxio.grpc.BlockHeartbeatPResponse.Builder
 
build() - Method in class alluxio.grpc.BlockIdList.Builder
 
build() - Method in class alluxio.grpc.BlockInfo.Builder
 
build() - Method in class alluxio.grpc.BlockLocation.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.BlockMasterClientServiceGrpc.BlockMasterClientServiceStub
 
build() - Method in class alluxio.grpc.BlockMasterInfo.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.BlockMasterWorkerServiceGrpc.BlockMasterWorkerServiceStub
 
build() - Method in class alluxio.grpc.BlockStatus.Builder
 
build() - Method in class alluxio.grpc.BlockStoreLocationProto.Builder
 
build(Channel, CallOptions) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerBlockingStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerFutureStub
 
build(Channel, CallOptions) - Method in class alluxio.grpc.BlockWorkerGrpc.BlockWorkerStub
 
build() - Method in class alluxio.grpc.BuildVersion.Builder
 
build() - Method in class alluxio.grpc.CacheRequest.Builder
 
build() - Method in class alluxio.grpc.CacheResponse.Builder
 
build() - Method in class alluxio.grpc.CancelPOptions.Builder
 
build() - Method in class alluxio.grpc.CancelPRequest.Builder
 
build() - Method in class alluxio.grpc.CancelPResponse.Builder
 
build() - Method in class alluxio.grpc.CancelTaskCommand.Builder
 
build() - Method in class alluxio.grpc.CheckAccessPOptions.Builder
 
build() - Method in class alluxio.grpc.CheckAccessPRequest.Builder
 
build() - Method in class alluxio.grpc.CheckAccessPResponse.Builder
 
build() - Method in class alluxio.grpc.CheckConsistencyPOptions.Builder
 
build() - Method in class alluxio.grpc.CheckConsistencyPRequest.Builder
 
build() - Method in class alluxio.grpc.CheckConsistencyPResponse.Builder
 
build() - Method in class alluxio.grpc.CheckpointPOptions.Builder
 
build() - Method in class alluxio.grpc.CheckpointPResponse.Builder
 
build() - Method in class alluxio.grpc.CheckRequest.Builder
 
build() - Method in class alluxio.grpc.CheckResponse.Builder
 
build() - Method in class alluxio.grpc.Chunk.Builder
 
build() - Method in class alluxio.grpc.ClearMetricsPRequest.Builder
 
build() - Method in class alluxio.grpc.ClearMetricsPResponse.Builder
 
build() - Method in class alluxio.grpc.ClearMetricsRequest.Builder
 
build() - Method in class alluxio.grpc.ClearMetricsResponse.Builder
 
build() - Method in class alluxio.grpc.ClientMetrics.Builder
 
build() - Method in class alluxio.grpc.CmdProgress.Builder
 
build() - Method in class alluxio.grpc.CmdStatusBlock.Builder
 
build() - Method in class alluxio.grpc.CmdSummary.Builder
 
build() - Method in class alluxio.grpc.Command.Builder
 
build() - Method in class alluxio.grpc.CommitBlockPOptions.Builder
 
build() - Method in class alluxio.grpc.CommitBlockPRequest.Builder
 
build() - Method in class alluxio.grpc.Commit